Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

AbstractBeanProcessor - Class in org.apache.camel.component.bean
A Processor which converts the inbound exchange to a method invocation on a POJO
AbstractBeanProcessor(Object, BeanInfo) - Constructor for class org.apache.camel.component.bean.AbstractBeanProcessor
 
AbstractBeanProcessor(Object, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.AbstractBeanProcessor
 
AbstractBeanProcessor(Object, CamelContext) - Constructor for class org.apache.camel.component.bean.AbstractBeanProcessor
 
AbstractBeanProcessor(BeanHolder) - Constructor for class org.apache.camel.component.bean.AbstractBeanProcessor
 
AbstractCamelContext - Class in org.apache.camel.impl
Represents the context used to configure routes and the policies to use.
AbstractCamelContext() - Constructor for class org.apache.camel.impl.AbstractCamelContext
Creates the CamelContext using DefaultRegistry as registry.
AbstractCamelContext(Registry) - Constructor for class org.apache.camel.impl.AbstractCamelContext
Creates the CamelContext using the given registry
AbstractCamelContext(boolean) - Constructor for class org.apache.camel.impl.AbstractCamelContext
 
AbstractCamelContext.Initialization - Enum in org.apache.camel.impl
 
AbstractCamelInvocationHandler - Class in org.apache.camel.component.bean
 
AbstractCamelInvocationHandler(Endpoint, Producer) - Constructor for class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
AbstractDynamicRegistry<K,V> - Class in org.apache.camel.impl
Base implementation for TransformerRegistry, ValidatorRegistry and EndpointRegistry.
AbstractDynamicRegistry(CamelContext, int) - Constructor for class org.apache.camel.impl.AbstractDynamicRegistry
 
AbstractListAggregationStrategy<V> - Class in org.apache.camel.processor.aggregate
Aggregate all exchanges into a List of values defined by the AbstractListAggregationStrategy.getValue(Exchange) call.
AbstractListAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
 
AbstractServiceRegistry - Class in org.apache.camel.impl.cloud
 
AbstractServiceRegistry() - Constructor for class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
AbstractServiceRegistry(String) - Constructor for class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
AbstractServiceRegistry(String, CamelContext) - Constructor for class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
accept(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Accept the given token.
acceptAndAddNode(SimpleNode) - Method in interface org.apache.camel.language.simple.ast.Block
Whether to accept and add the given node in this block.
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
acceptLeft(SimpleNode) - Method in class org.apache.camel.language.simple.ast.UnaryExpression
Accepts the left node to this operator
acceptLeftNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
acceptLeftNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
acceptRightNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
acceptRightNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
accessCode(String, String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
accumulateInCollection(Class<? extends Collection>) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Accumulate the result of the pick expression in a collection of the designated type.
aclToken(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the ACL token to be used with Consul
acquire(Endpoint) - Method in class org.apache.camel.impl.ServicePool
Tries to acquire the service with the given key
acquirePollingConsumer(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerCache
Acquires a pooled PollingConsumer which you must release back again after usage using the DefaultConsumerCache.releasePollingConsumer(org.apache.camel.Endpoint, org.apache.camel.PollingConsumer) method.
acquireProducer(Endpoint) - Method in class org.apache.camel.impl.DefaultProducerCache
Acquires a pooled producer which you must release back again after usage using the DefaultProducerCache.releaseProducer(org.apache.camel.Endpoint, org.apache.camel.AsyncProducer) method.
activate() - Method in class org.apache.camel.impl.BreakpointSupport
 
activateAllBreakpoints() - Method in class org.apache.camel.impl.DefaultDebugger
 
adapt(Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
add(String, String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
A helper method to make it easy to create newly populated instances
add(String, String) - Method in class org.apache.camel.builder.xml.Namespaces
 
add(Element) - Method in class org.apache.camel.builder.xml.Namespaces
 
add(String, Exchange) - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
add(Exchange) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
add(Exchange, String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
add(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
add(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
addAdvice(CamelInternalProcessorAdvice<?>) - Method in class org.apache.camel.processor.CamelInternalProcessor
Adds an CamelInternalProcessorAdvice advice to the list of advices to execute by this internal processor.
addAllMeta(Map<String, String>) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
addBreakpoint(Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
addBreakpoint(Breakpoint, Condition...) - Method in class org.apache.camel.impl.DefaultDebugger
 
addBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
addChild(SimpleNode) - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
addClassLoader(ClassLoader) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
addComponent(String, Component) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addConditionalBreakpoint(String, String, String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
addConfiguration(Object) - Method in class org.apache.camel.main.MainSupport
 
addConfigurationClass(Class...) - Method in class org.apache.camel.main.MainSupport
 
addDefaultValue(String, String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Adds a default value for the query parameter
addEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addEndpointToRegistry(String, Endpoint) - Method in class org.apache.camel.impl.AbstractCamelContext
Strategy to add the given endpoint to the internal endpoint registry
addErrorHandlers(RouteContext, OnExceptionDefinition) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Adds error handler for the given exception type
addErrorHandlers(RouteContext, OnExceptionDefinition) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
addErrorHandlers(RouteContext, OnExceptionDefinition) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
addEventDrivenProcessor(Processor) - Method in class org.apache.camel.impl.DefaultRouteContext
 
addEventNotifier(EventNotifier) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
addExceptionPolicy(RouteContext, OnExceptionDefinition) - Method in class org.apache.camel.processor.ErrorHandlerSupport
 
addFilter(ClusteredRouteFilter) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Add a filter used to to filter cluster aware routes.
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
addFilter(SupervisingRouteController.Filter) - Method in class org.apache.camel.impl.SupervisingRouteController
Add a filter used to determine the routes to supervise.
addHystrixConfiguration(String, HystrixConfigurationDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addHystrixConfiguration(String, HystrixConfigurationDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Adds the Hystrix configuration
addIfMatching(PackageScanFilter, String, Set<Class<?>>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
Add the class designated by the fully qualified class name provided to the set of resolved classes if and only if it is approved by the Test supplied.
addInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
addInterceptStrategies(RouteContext, Channel, List<InterceptStrategy>) - Method in class org.apache.camel.reifier.ProcessorReifier
Adds the given list of interceptors to the channel.
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultRouteContext
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
addLifecycleStrategy(LifecycleStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addLogListener(LogListener) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addMainListener(MainListener) - Method in class org.apache.camel.main.MainSupport
Adds a MainListener to receive callbacks when the main is started or stopping
addMeta(String, String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
addMethod(Object, Method, Endpoint, String) - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
addNewExchangeProcessor(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
addOption(MainSupport.Option) - Method in class org.apache.camel.main.MainSupport
 
addOutput(ProcessorDefinition<?>) - Method in interface org.apache.camel.model.Block
Adds the given definition as output to this block
addOutput(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ChoiceDefinition
 
addOutput(ProcessorDefinition<?>) - Method in class org.apache.camel.model.HystrixDefinition
 
addOutput(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ProcessorDefinition
 
addOutput(ProcessorDefinition<?>) - Method in class org.apache.camel.model.TryDefinition
 
addOutput(ProcessorDefinition<?>) - Method in class org.apache.camel.model.WireTapDefinition
 
addParameterMapping(Class<?>, Expression) - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
Adds a default parameter type mapping to an expression
addPredicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause
 
addProcessor(AsyncProcessor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Adds a new processor to the load balancer
addProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
addPropertyPlaceholdersChangeRevertAction(Runnable) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
 
addReceivedExchange(Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds the received exchange.
addRegisterEndpointCallback(EndpointStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRequiredHeader(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Adds a required HTTP header
addRequiredQueryParameter(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Adds a required query parameter
addRestConfiguration(RestConfiguration) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRestDefinitions(InputStream, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRestDefinitions(Collection<RestDefinition>, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRestDefinitions(InputStream, boolean) - Method in interface org.apache.camel.model.ModelCamelContext
Adds a collection of rest definitions to the context
addRestDefinitions(Collection<RestDefinition>, boolean) - Method in interface org.apache.camel.model.ModelCamelContext
Adds a collection of rest definitions to the context
addRestService(Consumer, String, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.camel.impl.DefaultRestRegistry
 
addRoute(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
addRouteBuilder(RouteBuilder) - Method in class org.apache.camel.main.MainSupport
 
addRouteBuilder(Class...) - Method in class org.apache.camel.main.MainSupport
 
addRouteConfiguration(String, ClusteredRouteConfiguration) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Add a configuration for the given route.
addRouteDefinition(RouteDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRouteDefinition(RouteDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Add a route definition to the context

Important: Each route in the same CamelContext must have an unique route id.

addRouteDefinitions(InputStream) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRouteDefinitions(InputStream) - Method in interface org.apache.camel.model.ModelCamelContext
Adds a collection of route definitions to the context

Important: Each route in the same CamelContext must have an unique route id.

addRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Adds a collection of route definitions to the context

Important: Each route in the same CamelContext must have an unique route id.

addRoutePolicyFactory(RoutePolicyFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRoutes(CamelContext, ThrowingConsumer<RouteBuilder, Exception>) - Static method in class org.apache.camel.builder.RouteBuilder
Add routes to a context using a lambda expression.
addRoutes(RoutesBuilder) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.reifier.ProcessorReifier
 
addRoutes(ModelCamelContext, Collection<Route>) - Method in class org.apache.camel.reifier.RouteReifier
 
addRoutes(CamelContext, Collection<Route>, FromDefinition) - Method in class org.apache.camel.reifier.RouteReifier
 
addRoutesToCamelContext(CamelContext) - Method in class org.apache.camel.builder.RouteBuilder
 
addServer(ServiceDefinition) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
Add a server to the known list of servers.
addServer(String) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
Add a server to the known list of servers to blacklist.
addServer(ServiceDefinition) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
Add a server to the known list of servers.
addServer(String) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
Add a server to the known list of servers.
addServers(String, List<String>) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
addService(Object) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addService(Object, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addService(Object, boolean, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addService(Service) - Method in class org.apache.camel.impl.DefaultRoute
 
addService(Service) - Method in class org.apache.camel.impl.DeferServiceStartupListener
 
addServiceCallConfiguration(String, ServiceCallConfigurationDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addServiceCallConfiguration(String, ServiceCallConfigurationDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Adds the service call configuration
addServiceDiscoveryConfigurations(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
Add a ServiceDiscovery configuration
addServiceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
Add a ServiceFilter configuration
addServices(List<Service>) - Method in class org.apache.camel.impl.DefaultRoute
Strategy method to allow derived classes to lazily load services for the route
addServices(List<Service>) - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
Factory method to lazily create the complete list of services required for this route such as adding the processor or consumer
addSingleStepBreakpoint(Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
addSingleStepBreakpoint(Breakpoint, Condition...) - Method in class org.apache.camel.impl.DefaultDebugger
 
addSpoolRule(StreamCachingStrategy.SpoolRule) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
addStartupListener(StartupListener) - Method in class org.apache.camel.impl.AbstractCamelContext
 
addSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
addText(String) - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
addText(String) - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Adds the given text to this model.
addToClassMap(String, DefaultFactoryFinder.ClassSupplier) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
addTypeAndSuperTypes(Class<?>, List<Class<?>>) - Method in class org.apache.camel.component.bean.MethodInfo
Adds the current class and all of its base classes (apart from Object to the given list
addVariable(String, Object) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
adviceWith(RouteDefinition, CamelContext, RouteBuilder) - Static method in class org.apache.camel.reifier.RouteReifier
 
adviceWith(RouteDefinition, ModelCamelContext, RouteBuilder) - Static method in class org.apache.camel.reifier.RouteReifier
Advices this route with the route builder.
adviceWith(CamelContext, RouteBuilder) - Method in class org.apache.camel.reifier.RouteReifier
 
adviceWith(ModelCamelContext, RouteBuilder) - Method in class org.apache.camel.reifier.RouteReifier
Advices this route with the route builder.
AdviceWithBuilder<T extends ProcessorDefinition<?>> - Class in org.apache.camel.builder
A builder when using the advice with feature.
AdviceWithBuilder(AdviceWithRouteBuilder, String, String, String, Class<T>) - Constructor for class org.apache.camel.builder.AdviceWithBuilder
 
AdviceWithRouteBuilder - Class in org.apache.camel.builder
A RouteBuilder which has extended capabilities when using the advice with feature.
AdviceWithRouteBuilder() - Constructor for class org.apache.camel.builder.AdviceWithRouteBuilder
 
AdviceWithTask - Interface in org.apache.camel.builder
Task or command being executed when using the advice with feature.
AdviceWithTasks - Class in org.apache.camel.builder
AdviceWithTask tasks which are used by the AdviceWithRouteBuilder.
after() - Method in class org.apache.camel.builder.AdviceWithBuilder
Insert the following node(s) after the matched node(s)
after(Exchange, StopWatch) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
after(Exchange, MessageHistory) - Method in class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
after(Exchange, StreamCache) - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
after(Exchange, UnitOfWork) - Method in class org.apache.camel.processor.CamelInternalProcessor.SubUnitOfWorkProcessorAdvice
 
after(Exchange, UnitOfWork) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
after(Exchange, T) - Method in interface org.apache.camel.processor.CamelInternalProcessorAdvice
Callback executed after processing a step in the route.
after(Exchange, T) - Method in class org.apache.camel.processor.CamelInternalProcessorAdvice.CamelInternalProcessorAdviceWrapper
 
after(Exchange, Object) - Method in class org.apache.camel.processor.ContractAdvice
 
after(Exchange, Map<String, Object>) - Method in class org.apache.camel.processor.RestBindingAdvice
 
afterById(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
afterByToString(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
afterByToUri(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
afterByType(RouteDefinition, Class<?>, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
afterInvoke(Method, Exchange, ExchangePattern, boolean) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
afterPrevious() - Method in class org.apache.camel.component.mock.TimeClause
 
afterProcess(Exchange, Processor, NamedNode, long) - Method in class org.apache.camel.impl.BreakpointSupport
 
afterProcess(Exchange, Processor, NamedNode, long) - Method in class org.apache.camel.impl.DefaultDebugger
 
afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
afterProcess(Exchange, Processor, ProcessorDefinition<?>, long) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
afterPropertiesSet() - Method in class org.apache.camel.model.InterceptDefinition
This method is only for handling some post configuration that is needed since this is an interceptor, and we have to do a bit of magic logic to fixup to handle predicates with or without proceed/stop set as well.
afterPropertiesSet() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
This method is only for handling some post configuration that is needed since this is an interceptor, and we have to do a bit of magic logic to fixup to handle predicates with or without proceed/stop set as well.
afterRoute(Exchange, Route) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
afterSend(ProcessorExchangePair, StopWatch) - Method in class org.apache.camel.processor.MulticastProcessor
 
afterStart(MainSupport) - Method in interface org.apache.camel.main.MainListener
Callback after the CamelContext has been started.
afterStart(MainSupport) - Method in class org.apache.camel.main.MainListenerSupport
 
afterStart() - Method in class org.apache.camel.main.MainSupport
Callback to run custom logic after CamelContext has been started.
afterStop(MainSupport) - Method in interface org.apache.camel.main.MainListener
Callback after the CamelContext has been stopped.
afterStop(MainSupport) - Method in class org.apache.camel.main.MainListenerSupport
 
afterStop() - Method in class org.apache.camel.main.MainSupport
Callback to run custom logic after CamelContext has been stopped.
aggregate(Exchange, Exchange) - Method in class org.apache.camel.builder.AggregationStrategyClause
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
 
aggregate() - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
This method will aggregate the old and new exchange and return the result.
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
aggregate() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
AGGREGATE_OPTIMISTIC_LOCKING_EXECUTOR - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
AGGREGATE_TIMEOUT_CHECKER - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
aggregateController(AggregateController) - Method in class org.apache.camel.model.AggregateDefinition
To use a AggregateController to allow external sources to control this aggregator.
AggregateController - Interface in org.apache.camel.processor.aggregate
A controller which allows controlling a AggregateProcessor from an external source, such as Java API or JMX.
AggregateDefinition - Class in org.apache.camel.model
Aggregates many messages into a single message
AggregateDefinition() - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Predicate) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Expression) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Expression, AggregationStrategy) - Constructor for class org.apache.camel.model.AggregateDefinition
 
aggregateOnException(boolean) - Method in class org.apache.camel.model.EnrichDefinition
If this option is false then the aggregate method is not used if there was an exception thrown while trying to retrieve the data to enrich from the resource.
aggregateOnException(boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
If this option is false then the aggregate method is not used if there was an exception thrown while trying to retrieve the data to enrich from the resource.
AggregateProcessor - Class in org.apache.camel.processor.aggregate
An implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
AggregateProcessor(CamelContext, AsyncProcessor, Expression, AggregationStrategy, ExecutorService, boolean) - Constructor for class org.apache.camel.processor.aggregate.AggregateProcessor
 
AggregateProcessorStatistics - Interface in org.apache.camel.processor.aggregate
Various statistics of the aggregator
aggregationRepository(AggregationRepository) - Method in class org.apache.camel.model.AggregateDefinition
Sets the custom aggregate repository to use.
aggregationRepositoryRef(String) - Method in class org.apache.camel.model.AggregateDefinition
Sets the custom aggregate repository to use

Will by default use MemoryAggregationRepository

AggregationStrategies - Class in org.apache.camel.builder
Toolbox class to create commonly used Aggregation Strategies in a fluent manner.
aggregationStrategy() - Method in class org.apache.camel.model.AggregateDefinition
Sets the AggregationStrategy to use with a fluent builder.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate strategy to use
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.ClaimCheckDefinition
To use a custom AggregationStrategy instead of the default implementation.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.EnrichDefinition
Sets the AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
aggregationStrategy() - Method in class org.apache.camel.model.MulticastDefinition
Sets the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast using a fluent builder.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastDefinition
Sets the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.PollEnrichDefinition
Sets the AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.RecipientListDefinition
Sets the AggregationStrategy to be used to assemble the replies from the recipients, into a single outgoing message from the RecipientList.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitDefinition
Sets the AggregationStrategy to be used to assemble the replies from the splitted messages, into a single outgoing message from the Splitter.
AggregationStrategyBeanAdapter - Class in org.apache.camel.processor.aggregate
An AggregationStrategy that adapts to a POJO.
AggregationStrategyBeanAdapter(Object) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Class<?>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Object, String) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Class<?>, String) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanInfo - Class in org.apache.camel.processor.aggregate
Class information about the POJO method to call when using the AggregationStrategyBeanAdapter.
AggregationStrategyBeanInfo(Class<?>, Method) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanInfo
 
AggregationStrategyClause<T> - Class in org.apache.camel.builder
 
AggregationStrategyClause(T) - Constructor for class org.apache.camel.builder.AggregationStrategyClause
 
aggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.AggregateDefinition
Sets allowing null when using a POJO as AggregationStrategy.
aggregationStrategyMethodAllowNull(boolean) - Method in class org.apache.camel.model.EnrichDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
aggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.MulticastDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
aggregationStrategyMethodAllowNull(boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
aggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.RecipientListDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
aggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.SplitDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
AggregationStrategyMethodInfo - Class in org.apache.camel.processor.aggregate
Method information about the POJO method to call when using the AggregationStrategyBeanAdapter.
AggregationStrategyMethodInfo(Method, List<ParameterInfo>, List<ParameterInfo>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.AggregateDefinition
Sets the method name to use when using a POJO as AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.EnrichDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.MulticastDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.PollEnrichDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.RecipientListDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyMethodName(String) - Method in class org.apache.camel.model.SplitDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate strategy to use
aggregationStrategyRef(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
To use a custom AggregationStrategy instead of the default implementation.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.EnrichDefinition
Refers to an AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.MulticastDefinition
Sets a reference to the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.PollEnrichDefinition
Refers to an AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
Sets a reference to the AggregationStrategy to be used to assemble the replies from the recipients, into a single outgoing message from the RecipientList.
aggregationStrategyRef(String) - Method in class org.apache.camel.model.SplitDefinition
Sets a reference to the AggregationStrategy to be used to assemble the replies from the splitted messages, into a single outgoing message from the Splitter.
AliasAdapter() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.AliasAdapter
 
AliasEntry() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
AliasEntry(String, String) - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
AliasList() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.AliasList
 
allMessages() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an assertion to all the received messages
allowableValues(List<String>) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Allowed values of the parameter when its an enum type
allowableValues(String...) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Allowed values of the parameter when its an enum type
allowableValues(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Allowed values of the parameter when its an enum type
allowableValues(List<String>) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Allowed values of the header when its an enum type
allowableValues(String...) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Allowed values of the parameter when its an enum type
allowCoreThreadTimeOut(Boolean) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
allowCoreThreadTimeOut(boolean) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
allowCoreThreadTimeOut(boolean) - Method in class org.apache.camel.model.ThreadsDefinition
Whether idle core threads is allowed to timeout and therefore can shrink the pool size below the core pool size

Is by default false

allowDuplicates() - Method in class org.apache.camel.model.ResequenceDefinition
Enables duplicates for the batch resequencer mode
allowEscape - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
allowMaximumSizeToDivergeFromCoreSize(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Allows the configuration for maximumSize to take effect.
allowOptimisedComponents(boolean) - Method in class org.apache.camel.model.ToDynamicDefinition
Whether to allow components to optimise toD if they are SendDynamicAware.
allowOptimisedComponents - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
allowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
allowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
allowRedeliveryWhileStopping(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
allowRedeliveryWhileStopping - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
allowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
AmbiguousMethodCallException - Exception in org.apache.camel.component.bean
An exception thrown if an attempted method invocation resulted in an ambiguous method such that multiple methods match the inbound message exchange
AmbiguousMethodCallException(Exchange, Collection<MethodInfo>) - Constructor for exception org.apache.camel.component.bean.AmbiguousMethodCallException
 
and() - Method in class org.apache.camel.builder.NotifyBuilder
Prepares to append an additional expression using the and operator.
and(Predicate, Predicate) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to combine multiple predicates by a logical AND
and(List<Predicate>) - Static method in class org.apache.camel.builder.PredicateBuilder
Concat the given predicates into a single predicate, which only matches if all the predicates matches.
and(Predicate...) - Static method in class org.apache.camel.builder.PredicateBuilder
Concat the given predicates into a single predicate, which only matches if all the predicates matches.
anExchange(CamelContext) - Static method in class org.apache.camel.builder.ExchangeBuilder
Create the exchange by setting the camel context
AnnotationExpressionFactory - Interface in org.apache.camel.component.bean
A factory which creates an Expression object from an annotation on a field, property or method parameter of a specified type.
apiComponent(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific Camel rest API component
apiContextIdPattern(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets an CamelContext id pattern to only allow Rest APIs from rest services within CamelContext's which name matches the pattern.
apiContextListing(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets whether listing of all available CamelContext's with REST services in the JVM is enabled.
apiContextPath(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets a leading context-path the REST services will be using.
apiContextRouteId(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the route id to use for the route that services the REST API.
apiDocAsJson() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
apiDocs(Boolean) - Method in class org.apache.camel.model.rest.RestDefinition
Include or exclude the current Rest Definition in API documentation.
apiHost(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To define a specific host to use for API documentation (eg swagger) instead of using a generated API hostname that is relative to the REST service host.
apiKey(String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
apiKey(String, String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
apiProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For configuring an api property, such as api.title, or api.version.
apiVendorExtension(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether vendor extension is enabled in the Rest APIs.
apiVersion(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the API version when using client lookup
append(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Appends the String evaluations of the two expressions together
append(Object) - Method in class org.apache.camel.builder.ValueBuilder
Appends the string evaluation of this expression with the given value
application(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
apply(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
 
apply(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.CombinedServiceFilter
 
apply(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.DefaultServiceFilter
 
apply(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.HealthyServiceFilter
 
apply(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.PassThroughServiceFilter
 
apply(Route) - Method in class org.apache.camel.impl.SupervisingRouteControllerFilters.BlackList
 
applyAssertionOn(MockEndpoint, int, Exchange) - Method in class org.apache.camel.component.mock.AssertionClause
Performs any assertions on the given exchange
applyHeaders(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
Allows derived classes to add some custom headers for a given message
arrayType(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
The data type of the array data type
arrayType(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
The data type of the array data type
arrives() - Method in class org.apache.camel.component.mock.AssertionClause
Adds a TimeClause predicate for message arriving.
asExpression(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
asMap() - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
 
asMap - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
asMap() - Method in class org.apache.camel.model.GlobalOptionsDefinition
 
asn1() - Method in class org.apache.camel.builder.DataFormatClause
Uses the ASN.1 file data format
asn1(String) - Method in class org.apache.camel.builder.DataFormatClause
 
asn1(Boolean) - Method in class org.apache.camel.builder.DataFormatClause
 
ASN1DataFormat - Class in org.apache.camel.model.dataformat
The ASN.1 data format is used for file transfer with telecommunications protocols.
ASN1DataFormat() - Constructor for class org.apache.camel.model.dataformat.ASN1DataFormat
 
ASN1DataFormat(Boolean) - Constructor for class org.apache.camel.model.dataformat.ASN1DataFormat
 
ASN1DataFormat(String) - Constructor for class org.apache.camel.model.dataformat.ASN1DataFormat
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
asRestConfiguration(CamelContext) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Creates a RestConfiguration instance based on the definition
asRouteApiDefinition(CamelContext, RestConfiguration) - Static method in class org.apache.camel.model.rest.RestDefinition
Transforms the rest api configuration into a RouteDefinition which Camel routing engine uses to service the rest api docs.
asRouteDefinition(CamelContext) - Method in class org.apache.camel.model.rest.RestDefinition
Transforms this REST definition into a list of RouteDefinition which Camel routing engine can add and run.
asRouteDefinition(CamelContext, RestConfiguration) - Method in class org.apache.camel.model.rest.RestDefinition
Transforms this REST definition into a list of RouteDefinition which Camel routing engine can add and run.
assertEquals(String, Object, Object, Exchange) - Static method in class org.apache.camel.component.dataset.DataSetEndpoint
 
assertEquals(String, Object, Object) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertExchangeReceived(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the given index of message is received (starting at zero)
AssertionClause - Class in org.apache.camel.component.mock
A builder of assertions on message exchanges
AssertionClause(MockEndpoint) - Constructor for class org.apache.camel.component.mock.AssertionClause
 
AssertionClause.PredicateValueBuilder - Class in org.apache.camel.component.mock
Public class needed for fluent builders
assertIsNotSatisfied() - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that the assertions fail on this endpoint
assertIsNotSatisfied(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that the assertions fail on this endpoint
assertIsSatisfied(long, TimeUnit, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
assertIsSatisfied(MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
assertIsSatisfied(CamelContext) - Static method in class org.apache.camel.component.mock.MockEndpoint
Asserts that all the expectations on any MockEndpoint instances registered in the given context are valid
assertIsSatisfied(CamelContext, long, TimeUnit) - Static method in class org.apache.camel.component.mock.MockEndpoint
Asserts that all the expectations on any MockEndpoint instances registered in the given context are valid
assertIsSatisfied() - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that all the available expectations on this endpoint are satisfied; or throw an exception
assertIsSatisfied(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that all the available expectations on this endpoint are satisfied; or throw an exception
assertMatches(String, Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
assertMessageExpected(DataSetEndpoint, Exchange, Exchange, long) - Method in interface org.apache.camel.component.dataset.DataSet
Asserts that the expected message has been received for the given index
assertMessageExpected(long, Exchange, Exchange) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
assertMessageExpected(DataSetEndpoint, Exchange, Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
assertMessagesAscending(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have ascending values of the given expression
assertMessagesDescending(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have descending values of the given expression
assertMessagesSorted(Expression, boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertNoDuplicates(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertTrue(String, boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertWait(long, TimeUnit, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
asVerb() - Method in class org.apache.camel.model.rest.VerbDefinition
 
asyncCallback(String, Exchange, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(String, Processor, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, Exchange, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, Processor, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, ExchangePattern, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackRequestBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackSendBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncDelayed() - Method in class org.apache.camel.model.DelayDefinition
Enables asynchronous delay which means the thread will not block while delaying.
asyncDelayed() - Method in class org.apache.camel.model.ThrottleDefinition
Enables asynchronous delay which means the thread will not block while delaying.
asyncDelayedRedelivery - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
asyncDelayedRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Will allow asynchronous delayed redeliveries.
asyncDelayedRedelivery() - Method in class org.apache.camel.model.OnExceptionDefinition
Allow synchronous delayed redelivery.
asyncDelayedRedelivery() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Allow synchronous delayed redelivery.
asyncDelayedRedelivery - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
asyncDelayedRedelivery() - Method in class org.apache.camel.processor.RedeliveryPolicy
Allow asynchronous delayed redelivery.
asyncDispatchExchange(Endpoint, AsyncProducer, Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.DefaultProducerCache
 
asyncRequest() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
asyncRequest(Class<T>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
asyncRequest(Endpoint, Processor, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
asyncSend(Endpoint, ExchangePattern, Processor, Processor, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.DefaultProducerCache
Asynchronously sends an exchange to an endpoint using a supplied Processor to populate the exchange
asyncSend(String, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(Endpoint, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(Endpoint, ExchangePattern, Processor, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSendBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSendBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.DefaultProducerCache
Asynchronously sends an exchange to an endpoint using a supplied Processor to populate the exchange
asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
attachmentObjectsExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message attachments
attachmentObjectValuesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message attachments
attachments() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the inbound message attachments
attachments() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the inbound message attachments
attachmentsExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message attachments
attachmentValuesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message attachments
attribute(String, Object) - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
attribute(QName, Object) - Method in class org.apache.camel.model.ProcessorDefinition
Adds an optional attribute
authorizationUrl(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
autoConfigurationEnabled - Variable in class org.apache.camel.main.MainSupport
 
autoConfigurationFromProperties(CamelContext) - Method in class org.apache.camel.main.MainSupport
 
autoConfigurationFromRegistry(CamelContext) - Method in class org.apache.camel.main.MainSupport
 
autoStartup(String) - Method in class org.apache.camel.model.RouteDefinition
Sets the auto startup property on this route.
autoStartup(boolean) - Method in class org.apache.camel.model.RouteDefinition
Sets the auto startup property on this route.
avro() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Avro data format
avro(Object) - Method in class org.apache.camel.builder.DataFormatClause
 
avro(String) - Method in class org.apache.camel.builder.DataFormatClause
 
AvroDataFormat - Class in org.apache.camel.model.dataformat
The Avro data format is used for serialization and deserialization of messages using Apache Avro binary dataformat.
AvroDataFormat() - Constructor for class org.apache.camel.model.dataformat.AvroDataFormat
 
AvroDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.AvroDataFormat
 
await() - Method in class org.apache.camel.component.mock.MockEndpoint
 
await(long, TimeUnit) - Method in class org.apache.camel.component.mock.MockEndpoint
 
await(Exchange, CountDownLatch) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
awaitManager - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
awaitTermination(ExecutorService, long) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 

B

BacklogDebugger - Class in org.apache.camel.processor.interceptor
A Debugger that has easy debugging functionality which can be used from JMX with ManagedBacklogDebuggerMBean.
BacklogDebuggerAdvice(BacklogDebugger, Processor, ProcessorDefinition<?>) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
BacklogTracer - Class in org.apache.camel.processor.interceptor
A tracer used for message tracing, storing a copy of the message details in a backlog.
BacklogTracerAdvice(BacklogTracer, ProcessorDefinition<?>, ProcessorDefinition<?>, boolean) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
backOffMultiplier(double) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
backOffMultiplier(double) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the back off multiplier
backOffMultiplier(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the back off multiplier (supports property placeholders)
backOffMultiplier(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the back off multiplier
backOffMultiplier(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the back off multiplier (supports property placeholders)
backOffMultiplier - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
backOffMultiplier(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables exponential backoff and sets the multiplier used to increase the delay between redeliveries
BarcodeDataFormat - Class in org.apache.camel.model.dataformat
The Barcode data format is used for creating barccode images (such as QR-Code)
BarcodeDataFormat() - Constructor for class org.apache.camel.model.dataformat.BarcodeDataFormat
 
base64() - Method in class org.apache.camel.builder.DataFormatClause
Uses the base64 data format
base64(int, String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the base64 data format
Base64DataFormat - Class in org.apache.camel.model.dataformat
The Base64 data format is used for base64 encoding and decoding.
Base64DataFormat() - Constructor for class org.apache.camel.model.dataformat.Base64DataFormat
 
basePath(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
BaseSimpleNode - Class in org.apache.camel.language.simple.ast
Base class for SimpleNode nodes.
BaseSimpleNode(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.BaseSimpleNode
 
BaseSimpleParser - Class in org.apache.camel.language.simple
Base class for Simple language parser.
BaseSimpleParser(String, boolean) - Constructor for class org.apache.camel.language.simple.BaseSimpleParser
 
basicAuth(String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
basicAuth(String, String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
batch() - Method in class org.apache.camel.model.ResequenceDefinition
Configures the batch-based resequencing algorithm using the default configuration.
batch(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
Configures the batch-based resequencing algorithm using the given BatchResequencerConfig.
BatchResequencerConfig - Class in org.apache.camel.model.config
Configures batch-processing resequence eip.
BatchResequencerConfig() - Constructor for class org.apache.camel.model.config.BatchResequencerConfig
Creates a new BatchResequencerConfig instance using default values for batchSize (100) and batchTimeout (1000L).
BatchResequencerConfig(int, long) - Constructor for class org.apache.camel.model.config.BatchResequencerConfig
Creates a new BatchResequencerConfig instance using the given values for batchSize and batchTimeout.
bean(Object) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
bean(Object, String) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
bean(Class<?>) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
bean(Class<?>, String) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
bean(Object) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder.
bean(Object, String) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder.
bean(Class<?>, String) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder
Bean - Annotation Type in org.apache.camel.language
Used to inject a bean expression into a field, property, method or parameter when using Bean Integration.
bean(String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression based on the string syntax.
bean(Class<?>, String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression for invoking the bean type.
bean(Object, String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression for invoking the bean type.
bean(Object) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Object, String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Object, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Object, String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Class<?>) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Class<?>, String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Class<?>, String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
BEAN_PARAMETER_MAPPING_STRATEGY - Static variable in class org.apache.camel.component.bean.BeanConstants
 
beanAllowNull(Object, String) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
beanAllowNull(Class<?>, String) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a AggregationStrategyBeanAdapter for using a POJO as the aggregation strategy.
BeanAnnotationExpressionFactory - Class in org.apache.camel.component.bean
 
BeanAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.BeanAnnotationExpressionFactory
 
BeanComponent - Class in org.apache.camel.component.bean
The Bean Component is for invoking Java beans from Camel.
BeanComponent() - Constructor for class org.apache.camel.component.bean.BeanComponent
 
BeanConstants - Class in org.apache.camel.component.bean
 
BeanConverter - Class in org.apache.camel.component.bean
A set of converter methods for working with beans
BeanConverterLoader - Class in org.apache.camel.component.bean
 
BeanConverterLoader() - Constructor for class org.apache.camel.component.bean.BeanConverterLoader
 
BeanDefinition - Class in org.apache.camel.model
Calls a java bean
BeanDefinition() - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanDefinition(String) - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanDefinition(String, String) - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanEndpoint - Class in org.apache.camel.component.bean
The bean component is for invoking Java beans from Camel.
BeanEndpoint() - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String, Component, BeanProcessor) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String, Component) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
beanExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
beanExpression(Class<?>, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Deprecated.
beanExpression(Object, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Deprecated.
beanExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Deprecated.
BeanExpression - Class in org.apache.camel.language.bean
Evaluates an expression using a bean method invocation
BeanExpression(Object, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanExpression(String, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanExpression(Class<?>, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanExpression(BeanHolder, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanExpressionProcessor - Class in org.apache.camel.component.bean
A bean processor that is optimised for being invoked one time from an BeanExpression.
BeanExpressionProcessor(BeanHolder) - Constructor for class org.apache.camel.component.bean.BeanExpressionProcessor
 
BeanHelper - Class in org.apache.camel.component.bean
Helper for the bean component.
BeanHolder - Interface in org.apache.camel.component.bean
Object holder for a bean.
BeanInfo - Class in org.apache.camel.component.bean
Represents the metadata about a bean type created via a combination of introspection and annotations together with some useful sensible defaults
BeanInfo(CamelContext, Class<?>) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInfo(CamelContext, Method) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInfo(CamelContext, Class<?>, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInfo(CamelContext, Class<?>, Method, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInfoCacheKey - Class in org.apache.camel.component.bean
A key used for caching BeanInfo by the BeanComponent
BeanInfoCacheKey(Class<?>, Method) - Constructor for class org.apache.camel.component.bean.BeanInfoCacheKey
 
BeanInvocation - Class in org.apache.camel.component.bean
Invocation of beans that can handle being serialized.
BeanInvocation() - Constructor for class org.apache.camel.component.bean.BeanInvocation
 
BeanInvocation(Method, Object[]) - Constructor for class org.apache.camel.component.bean.BeanInvocation
 
beanio(String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the beanio data format
beanio(String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the beanio data format
beanio(String, String, String, boolean, boolean, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the beanio data format
beanio(String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the beanio data format
BeanioDataFormat - Class in org.apache.camel.model.dataformat
The BeanIO data format is used for working with flat payloads (such as CSV, delimited, or fixed length formats).
BeanioDataFormat() - Constructor for class org.apache.camel.model.dataformat.BeanioDataFormat
 
BeanLanguage - Class in org.apache.camel.language.bean
A bean language which uses a simple text notation to invoke methods on beans to evaluate predicates or expressions

The notation is essentially beanName.methodName which is then invoked using the beanName to lookup in the bean integration to bind the Exchange to the method arguments.

BeanLanguage() - Constructor for class org.apache.camel.language.bean.BeanLanguage
 
beanName() - Method in class org.apache.camel.model.language.MethodCallExpression
 
BeanProcessor - Class in org.apache.camel.component.bean
 
BeanProcessor(Object, BeanInfo) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(Object, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(Object, CamelContext) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(BeanHolder) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProducer - Class in org.apache.camel.component.bean
Bean Producer
BeanProducer(BeanEndpoint, BeanProcessor) - Constructor for class org.apache.camel.component.bean.BeanProducer
 
BeanTypeHolder - Interface in org.apache.camel.component.bean
Object holder for a bean type.
before() - Method in class org.apache.camel.builder.AdviceWithBuilder
Insert the following node(s) before the matched node(s)
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.SubUnitOfWorkProcessorAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
before(Exchange) - Method in interface org.apache.camel.processor.CamelInternalProcessorAdvice
Callback executed before processing a step in the route.
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessorAdvice.CamelInternalProcessorAdviceWrapper
 
before(Exchange) - Method in class org.apache.camel.processor.ContractAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.RestBindingAdvice
 
beforeById(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
beforeByToString(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
beforeByToUri(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
beforeByType(RouteDefinition, Class<?>, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
beforeNext() - Method in class org.apache.camel.component.mock.TimeClause
 
beforeProcess(Exchange, Processor, NamedNode) - Method in class org.apache.camel.impl.BreakpointSupport
 
beforeProcess(Exchange, Processor, NamedNode) - Method in class org.apache.camel.impl.DefaultDebugger
 
beforeProcess(Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
beforeProcess(Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
beforeProcess(Exchange, Processor, ProcessorDefinition<?>) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
beforeRoute(Exchange, Route) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
beforeSend(ProcessorExchangePair) - Method in class org.apache.camel.processor.MulticastProcessor
 
beforeStart(MainSupport) - Method in interface org.apache.camel.main.MainListener
Callback before the CamelContext is being created and started.
beforeStart(MainSupport) - Method in class org.apache.camel.main.MainListenerSupport
 
beforeStart() - Method in class org.apache.camel.main.MainSupport
Callback to run custom logic before CamelContext is being started.
beforeStop(MainSupport) - Method in interface org.apache.camel.main.MainListener
Callback before the CamelContext is being stopped.
beforeStop(MainSupport) - Method in class org.apache.camel.main.MainListenerSupport
 
beforeStop() - Method in class org.apache.camel.main.MainSupport
Callback to run custom logic before CamelContext is being stopped.
begin() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
beginSubUnitOfWork(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
beginTransactedBy(Object) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
beginTransactedBy(Object) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
between(int, int) - Method in class org.apache.camel.component.mock.TimeClause
 
BinaryExpression - Class in org.apache.camel.language.simple.ast
Represents a binary expression in the AST.
BinaryExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.BinaryExpression
 
binaryOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
BinaryOperatorType - Enum in org.apache.camel.language.simple.types
Types of binary operators supported
BinaryOperatorType.ParameterType - Enum in org.apache.camel.language.simple.types
Parameter types a binary operator supports on the right hand side.
BinaryPredicateSupport - Class in org.apache.camel.builder
A useful base class for Predicate implementations
BinaryPredicateSupport(Expression, Expression) - Constructor for class org.apache.camel.builder.BinaryPredicateSupport
 
bind(String, Class<?>, Object) - Method in class org.apache.camel.impl.JndiRegistry
Deprecated.
 
bind(String, Object) - Method in class org.apache.camel.main.Main
Binds the given name to the bean object, so that it can be looked up inside the CamelContext this command line tool runs with.
binding(boolean) - Method in class org.apache.camel.builder.ProxyBuilder
Whether to use binding or not.
bindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify the binding mode
bindingMode(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify the binding mode
bindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.RestDefinition
 
bindingMode(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
bindToRegistry(String, Object) - Method in class org.apache.camel.builder.RouteBuilder
Binds the bean to the repository (if possible).
bindToRegistry(String, Class<?>, Object) - Method in class org.apache.camel.builder.RouteBuilder
Binds the bean to the repository (if possible).
bindy(BindyType, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Bindy data format
bindy(BindyType, Class<?>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Bindy data format
BindyDataFormat - Class in org.apache.camel.model.dataformat
The Bindy data format is used for working with flat payloads (such as CSV, delimited, fixed length formats, or FIX messages).
BindyDataFormat() - Constructor for class org.apache.camel.model.dataformat.BindyDataFormat
 
BindyType - Enum in org.apache.camel.model.dataformat
Represents the different types of bindy data formats.
BlackList(String) - Constructor for class org.apache.camel.impl.cluster.ClusteredRouteFilters.BlackList
 
BlackList(Collection<String>) - Constructor for class org.apache.camel.impl.cluster.ClusteredRouteFilters.BlackList
 
BlackList(String) - Constructor for class org.apache.camel.impl.SupervisingRouteControllerFilters.BlackList
 
BlackList(Collection<String>) - Constructor for class org.apache.camel.impl.SupervisingRouteControllerFilters.BlackList
 
blacklistFilter() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
blacklistFilter() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
BlacklistServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
BlacklistServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
 
BlacklistServiceCallServiceFilterConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
 
BlacklistServiceFilter - Class in org.apache.camel.impl.cloud
 
BlacklistServiceFilter() - Constructor for class org.apache.camel.impl.cloud.BlacklistServiceFilter
 
BlacklistServiceFilter(List<ServiceDefinition>) - Constructor for class org.apache.camel.impl.cloud.BlacklistServiceFilter
 
BlacklistServiceFilterFactory - Class in org.apache.camel.impl.cloud
 
BlacklistServiceFilterFactory() - Constructor for class org.apache.camel.impl.cloud.BlacklistServiceFilterFactory
 
Block - Interface in org.apache.camel.language.simple.ast
A model which is a block, containing other nodes.
Block - Interface in org.apache.camel.model
Interface to add block featuring to the XML element type.
BlockEnd - Interface in org.apache.camel.language.simple.ast
Marks an end of a block.
blockSeconds(Integer) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The seconds to wait for a watch event, default 10 seconds
BlockStart - Interface in org.apache.camel.language.simple.ast
Marks a start of a block.
body(BiFunction<Object, Object, Object>) - Method in class org.apache.camel.builder.AggregationStrategyClause
Define an aggregation strategy which targets Exchanges In Body.
body(Class<B>, BiFunction<B, B, Object>) - Method in class org.apache.camel.builder.AggregationStrategyClause
Define an aggregation strategy which targets Exchanges In Body.
body(Class<O>, Class<N>, BiFunction<O, N, Object>) - Method in class org.apache.camel.builder.AggregationStrategyClause
Define an aggregation strategy which targets Exchanges In Body.
body() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the inbound body on an exchange
body() - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the inbound body on an exchange
body() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message body
body(Function<Object, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message body
body(Supplier<Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message body
body(BiFunction<Object, Map<String, Object>, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message body and headers
body(Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message body converted to the expected type
body(Class<B>, Function<B, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message body converted to the expected type
body(Class<B>, BiFunction<B, Map<String, Object>, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message body converted to the expected type and headers
body() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an inbound message body
body(Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an inbound message body converted to the expected type
body(Predicate<Object>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the Exchange In Body.
body(Class<B>, Predicate<B>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the typed Exchange In Body.
body(BiPredicate<Object, Map<String, Object>>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the Exchange In Body and its Headers.
body(Class<B>, BiPredicate<B, Map<String, Object>>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the typed Exchange In Body and its Headers.
body(Consumer<Object>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the Exchange In Body.
body(Class<B>, Consumer<B>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the typed Exchange In Body.
body(BiConsumer<Object, Map<String, Object>>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the Exchange In Body and its Headers.
body(Class<B>, BiConsumer<B, Map<String, Object>>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the typed Exchange In Body and its Headers.
bodyAs(Class<T>) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the inbound message body as a specific type
bodyAs(Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the inbound message body as a specific type
bodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body
bodyExpression(Function<Object, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the exchanges inbound message body
bodyExpression(BiFunction<Object, Map<String, Object>, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the exchanges inbound message body and headers
bodyExpression(Class<T>, Function<T, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the exchanges inbound message body converted to a desired type
bodyExpression(Class<T>, BiFunction<T, Map<String, Object>, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the exchanges inbound message body converted to a desired type and headers
bodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
bodyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
bodyOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body invoking methods defined in a simple OGNL notation
bodyOgnlExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type and invoking methods on the converted body defined in a simple OGNL notation
bodyParameterMatches(Class<?>) - Method in class org.apache.camel.component.bean.MethodInfo
 
bodyTypeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body type
booleanResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to XPathConstants.BOOLEAN
booleanValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
boon(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Boon data format
BoonDataFormat - Class in org.apache.camel.model.dataformat
Boon data format is used for unmarshal a JSon payload to POJO or to marshal POJO back to JSon payload.
BoonDataFormat() - Constructor for class org.apache.camel.model.dataformat.BoonDataFormat
 
BoonDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.BoonDataFormat
 
BreakpointSupport - Class in org.apache.camel.impl
A support class for Breakpoint implementations to use as base class.
BreakpointSupport() - Constructor for class org.apache.camel.impl.BreakpointSupport
 
browse() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
browse() - Method in class org.apache.camel.impl.DefaultInflightRepository
 
browse(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
browse(int, boolean) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
browse(String, int, boolean) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
build() - Method in class org.apache.camel.builder.ExchangeBuilder
Build up the exchange from the exchange builder
build(Class<T>) - Method in class org.apache.camel.builder.ProxyBuilder
Builds the proxy.
build(Class<T>...) - Method in class org.apache.camel.builder.ProxyBuilder
Builds the proxy.
build() - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new thread pool
build(String) - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new thread pool
build(Object, String) - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new thread pool
build() - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
Builds the thread pool profile
build() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
build() - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
buildCamelEndpointUri(String, String, Integer, String, String, String) - Method in class org.apache.camel.impl.cloud.DefaultServiceCallExpression
 
Builder - Class in org.apache.camel.builder
A helper class for including portions of the expression and predicate Java DSL

Implementation of this builder should favor build expressions using the definition classes from the org.apache.camel.model.language package, to build the routes using the same types as it would happen when using XML DSL.

builder() - Static method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
Builder() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
BuilderSupport - Class in org.apache.camel.builder
Base class for implementation inheritance for different clauses in the Java DSL
BuilderSupport() - Constructor for class org.apache.camel.builder.BuilderSupport
 
BuilderSupport(CamelContext) - Constructor for class org.apache.camel.builder.BuilderSupport
 
buildFromUri(VerbDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
Build the from endpoint uri for the verb
buildScheduled() - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new scheduled thread pool
buildScheduled(String) - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new scheduled thread pool
buildScheduled(Object, String) - Method in class org.apache.camel.builder.ThreadPoolBuilder
Builds the new scheduled thread pool

C

caCertData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Certificate Authority data when using client lookup
caCertFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Certificate Authority data that are loaded from the file when using client lookup
cache(Exchange) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
cache - Variable in class org.apache.camel.impl.ReloadStrategySupport
 
cacheExpression(Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression that caches the evaluation of another expression and returns the cached value, to avoid re-evaluating the expression.
cacheSize(int) - Method in class org.apache.camel.model.DynamicRouterDefinition
Sets the maximum size used by the ProducerCache which is used to cache and reuse producers when using this dynamic router, when uris are reused.
cacheSize(int) - Method in class org.apache.camel.model.EnrichDefinition
Sets the maximum size used by the ProducerCache which is used to cache and reuse producer when uris are reused.
cacheSize(int) - Method in class org.apache.camel.model.PollEnrichDefinition
Sets the maximum size used by the ConsumerCache which is used to cache and reuse consumers when uris are reused.
cacheSize(int) - Method in class org.apache.camel.model.RecipientListDefinition
Sets the maximum size used by the ProducerCache which is used to cache and reuse producers when using this recipient list, when uris are reused.
cacheSize(int) - Method in class org.apache.camel.model.RoutingSlipDefinition
Sets the maximum size used by the ProducerCache which is used to cache and reuse producers when using this routing slip, when uris are reused.
cacheSize(int) - Method in class org.apache.camel.model.ToDynamicDefinition
Sets the maximum size used by the ConsumerCache which is used to cache and reuse producers.
cacheSize(int) - Method in class org.apache.camel.model.WireTapDefinition
Sets the maximum size used by the ProducerCache which is used to cache and reuse producers, when uris are reused.
cacheSize - Variable in class org.apache.camel.processor.RoutingSlip
 
cacheSize - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
CachingServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
CachingServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
CachingServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
CachingServiceDiscovery - Class in org.apache.camel.impl.cloud
 
CachingServiceDiscovery(ServiceDiscovery) - Constructor for class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
CachingServiceDiscovery(ServiceDiscovery, long, TimeUnit) - Constructor for class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
CachingServiceDiscovery(ServiceDiscovery, long) - Constructor for class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
cachingServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
cachingServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
cachingServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
cachingServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
CachingServiceDiscoveryFactory - Class in org.apache.camel.impl.cloud
 
CachingServiceDiscoveryFactory() - Constructor for class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
calculateDelay(Exchange) - Method in class org.apache.camel.processor.Delayer
 
calculateDelay(Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
calculateRedeliverDelayUsingPattern(String, int) - Static method in class org.apache.camel.processor.RedeliveryPolicy
Calculates the delay using the delay pattern
calculateRedeliveryDelay(long, int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Calculates the new redelivery delay based on the last one
callerRunsWhenRejected(boolean) - Method in class org.apache.camel.model.DelayDefinition
Whether or not the caller should run the task when it was rejected by the thread pool.
callerRunsWhenRejected(boolean) - Method in class org.apache.camel.model.ThreadsDefinition
Whether or not to use as caller runs as fallback when a task is rejected being added to the thread pool (when its full).
callerRunsWhenRejected(boolean) - Method in class org.apache.camel.model.ThrottleDefinition
Whether or not the caller should run the task when it was rejected by the thread pool.
camelContext - Variable in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
camelContext - Variable in class org.apache.camel.main.MainSupport
 
camelContext - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
camelContext - Variable in class org.apache.camel.processor.RoutingSlip
 
camelContext - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
camelContext(CamelContext) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
camelContext - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
camelContext - Variable in class org.apache.camel.processor.SendProcessor
 
camelContextExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the CamelContext
camelContextNameExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the CamelContext name
camelContextOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges camelContext invoking methods defined in a simple OGNL notation
camelContextPropertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the properties of the camel context
camelContextPropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value of the camel context with the given name
CamelInternalProcessor - Class in org.apache.camel.processor
Internal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWork Keeping track which route currently is being routed Execute RoutePolicy Gather JMX performance statics Tracing Debugging Message History Stream Caching Transformer ...
CamelInternalProcessor() - Constructor for class org.apache.camel.processor.CamelInternalProcessor
 
CamelInternalProcessor(Processor) - Constructor for class org.apache.camel.processor.CamelInternalProcessor
 
CamelInternalProcessor.BacklogDebuggerAdvice - Class in org.apache.camel.processor
Advice to execute the BacklogDebugger if enabled.
CamelInternalProcessor.BacklogTracerAdvice - Class in org.apache.camel.processor
Advice to execute the BacklogTracer if enabled.
CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice - Class in org.apache.camel.processor
Advice when an EIP uses the shareUnitOfWork functionality.
CamelInternalProcessor.DelayerAdvice - Class in org.apache.camel.processor
Advice for delaying
CamelInternalProcessor.MessageHistoryAdvice - Class in org.apache.camel.processor
Advice when Message History has been enabled.
CamelInternalProcessor.RouteInflightRepositoryAdvice - Class in org.apache.camel.processor
Advice to keep the InflightRepository up to date.
CamelInternalProcessor.RouteLifecycleAdvice - Class in org.apache.camel.processor
Advice to invoke callbacks for before and after routing.
CamelInternalProcessor.RoutePolicyAdvice - Class in org.apache.camel.processor
Advice to execute any RoutePolicy a route may have been configured with.
CamelInternalProcessor.StreamCachingAdvice - Class in org.apache.camel.processor
Advice for StreamCachingStrategy
CamelInternalProcessor.SubUnitOfWorkProcessorAdvice - Class in org.apache.camel.processor
Advice when an EIP uses the shareUnitOfWork functionality.
CamelInternalProcessor.UnitOfWorkProcessorAdvice - Class in org.apache.camel.processor
Advice to inject new UnitOfWork to the Exchange if needed, and as well to ensure the UnitOfWork is done and stopped.
CamelInternalProcessorAdvice<T> - Interface in org.apache.camel.processor
An advice (before and after) to execute cross cutting functionality in the Camel routing engine.
CamelInternalProcessorAdvice.CamelInternalProcessorAdviceWrapper<T> - Class in org.apache.camel.processor
 
CamelInternalProcessorAdviceWrapper(ManagementInterceptStrategy.InstrumentationProcessor<T>) - Constructor for class org.apache.camel.processor.CamelInternalProcessorAdvice.CamelInternalProcessorAdviceWrapper
 
CamelInvocationHandler - Class in org.apache.camel.component.bean
An InvocationHandler which invokes a message exchange on a camel Endpoint
CamelInvocationHandler(Endpoint, boolean, Producer, MethodInfoCache) - Constructor for class org.apache.camel.component.bean.CamelInvocationHandler
 
CamelPostProcessorHelper - Class in org.apache.camel.impl
A helper class for Camel based injector or post processing hooks which can be reused by both the Spring, Guice and Blueprint support.
CamelPostProcessorHelper() - Constructor for class org.apache.camel.impl.CamelPostProcessorHelper
 
CamelPostProcessorHelper(CamelContext) - Constructor for class org.apache.camel.impl.CamelPostProcessorHelper
 
camelPostProcessorHelper - Variable in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
camelTemplate - Variable in class org.apache.camel.main.MainSupport
 
canPostProcessBean(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
canPreComplete() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
canSetCamelContext(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
capacity(int) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the capacity for the stream resequencer
castAs(Class<E>) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Cast the result of the pick expression to this type.
catchClauses - Variable in class org.apache.camel.processor.TryProcessor
 
CatchDefinition - Class in org.apache.camel.model
Catches exceptions as part of a try, catch, finally block
CatchDefinition() - Constructor for class org.apache.camel.model.CatchDefinition
 
CatchDefinition(List<Class<? extends Throwable>>) - Constructor for class org.apache.camel.model.CatchDefinition
 
CatchDefinition(Class<? extends Throwable>) - Constructor for class org.apache.camel.model.CatchDefinition
 
catches(Exchange, Throwable) - Method in class org.apache.camel.processor.CatchProcessor
Returns with the exception that is caught by this processor.
CatchProcessor - Class in org.apache.camel.processor
A processor which catches exceptions.
CatchProcessor(List<Class<? extends Throwable>>, Processor, Predicate, Predicate) - Constructor for class org.apache.camel.processor.CatchProcessor
 
changeFunctionEndToken(String...) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Change the end tokens used for functions.
changeFunctionEndToken(String...) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
 
changeFunctionStartToken(String...) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Change the start tokens used for functions.
changeFunctionStartToken(String...) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
 
changeOutput(Processor) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Allows to change the output of the error handler which are used when optimising the JMX instrumentation to use either an advice or wrapped processor when calling a processor.
checkException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
checkInitialized() - Method in class org.apache.camel.builder.RouteBuilder
 
checkInitialized() - Method in class org.apache.camel.model.TryDefinition
Checks whether or not this object has been initialized
checkNoCompletedPredicate() - Method in class org.apache.camel.model.AggregateDefinition
 
childProcessor(Processor) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
ChildUnitOfWorkProcessorAdvice(RouteContext, UnitOfWork) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice
 
choice() - Method in class org.apache.camel.model.ProcessorDefinition
Content Based Router EIP: Creates a choice of one or more predicates with an otherwise clause
ChoiceDefinition - Class in org.apache.camel.model
Routes messages based on a series of predicates
ChoiceDefinition() - Constructor for class org.apache.camel.model.ChoiceDefinition
 
ChoiceProcessor - Class in org.apache.camel.processor
Implements a Choice structure where one or more predicates are used which if they are true their processors are used, with a default otherwise clause used if none match.
ChoiceProcessor(List<FilterProcessor>, Processor) - Constructor for class org.apache.camel.processor.ChoiceProcessor
 
choose(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.RandomServiceChooser
 
choose(List<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.RoundRobinServiceChooser
 
chooseMethod(Object, Exchange, String) - Method in class org.apache.camel.component.bean.BeanInfo
Choose one of the available methods to invoke if we can match the message body to the body parameter
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.WeightedRandomLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
circuitBreakerEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether to use a HystrixCircuitBreaker or not.
circuitBreakerErrorThresholdPercentage(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Error percentage threshold (as whole number such as 50) at which point the circuit breaker will trip open and reject requests.
circuitBreakerForceClosed(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
If true the HystrixCircuitBreaker.allowRequest() will always return true to allow requests regardless of the error percentage from HystrixCommandMetrics.getHealthCounts().
circuitBreakerForceOpen(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
If true the HystrixCircuitBreaker.allowRequest() will always return false, causing the circuit to be open (tripped) and reject all requests.
circuitBreakerRequestVolumeThreshold(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Minimum number of requests in the metricsRollingStatisticalWindowInMilliseconds() that must exist before the HystrixCircuitBreaker will trip.
circuitBreakerSleepWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
The time in milliseconds after a HystrixCircuitBreaker trips open that it should wait before trying requests again.
claimCheck() - Method in class org.apache.camel.model.ProcessorDefinition
The Claim Check EIP allows you to replace message content with a claim check (a unique key), which can be used to retrieve the message content at a later time.
claimCheck(ClaimCheckOperation) - Method in class org.apache.camel.model.ProcessorDefinition
The Claim Check EIP allows you to replace message content with a claim check (a unique key), which can be used to retrieve the message content at a later time.
claimCheck(ClaimCheckOperation, String) - Method in class org.apache.camel.model.ProcessorDefinition
The Claim Check EIP allows you to replace message content with a claim check (a unique key), which can be used to retrieve the message content at a later time.
claimCheck(ClaimCheckOperation, String, String) - Method in class org.apache.camel.model.ProcessorDefinition
The Claim Check EIP allows you to replace message content with a claim check (a unique key), which can be used to retrieve the message content at a later time.
ClaimCheckAggregationStrategy - Class in org.apache.camel.processor
Default AggregationStrategy used by the ClaimCheckProcessor EIP.
ClaimCheckAggregationStrategy() - Constructor for class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
ClaimCheckDefinition - Class in org.apache.camel.model
The Claim Check EIP allows you to replace message content with a claim check (a unique key), which can be used to retrieve the message content at a later time.
ClaimCheckDefinition() - Constructor for class org.apache.camel.model.ClaimCheckDefinition
 
ClaimCheckOperation - Enum in org.apache.camel.model
Operations for the Claim Check EIP.
ClaimCheckProcessor - Class in org.apache.camel.processor
ClaimCheck EIP implementation.
ClaimCheckProcessor() - Constructor for class org.apache.camel.processor.ClaimCheckProcessor
 
ClassComponent - Class in org.apache.camel.component.beanclass
The Class Component is for binding JavaBeans to Camel message exchanges based on class name.
ClassComponent() - Constructor for class org.apache.camel.component.beanclass.ClassComponent
 
ClassEndpoint - Class in org.apache.camel.component.beanclass
The Class Component is for invoking Java Classes (Java beans) from Camel.
ClassEndpoint(String, Component) - Constructor for class org.apache.camel.component.beanclass.ClassEndpoint
 
cleanUp() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
cleanUp() - Method in class org.apache.camel.impl.DefaultConsumerCache
Cleanup the cache (purging stale entries)
cleanUp() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.DefaultProducerCache
Cleanup the cache (purging stale entries)
cleanUp() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.ServicePool
 
clear() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
clear() - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
clear() - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
clear() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
clear() - Method in class org.apache.camel.impl.MDCUnitOfWork
Clears information put on the MDC by this MDCUnitOfWork
clear() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Clears the parser state, which means it can be used for parsing a new input.
clear() - Method in class org.apache.camel.model.ContextScanDefinition
 
clear() - Method in class org.apache.camel.model.FromDefinition
 
clear() - Method in class org.apache.camel.model.PackageScanDefinition
 
clear() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Clear the idempotent repository
clear() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
clearAll() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
clearBody() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
clearClosedCorrelationKeysCache() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Clear all the closed correlation keys stored in the cache
clearHeaders() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
clearOutput() - Method in class org.apache.camel.model.ProcessorDefinition
 
clientCertData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Certificate data when using client lookup
clientCertFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Certificate data that are loaded from the file when using client lookup
clientKeyAlgo(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore algorithm, such as RSA when using client lookup
clientKeyData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore data when using client lookup
clientKeyFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore data that are loaded from the file when using client lookup
clientKeyPassphrase(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore passphrase when using client lookup
clientName(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
Sets the Ribbon client name
clientRequestValidation(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
clientRequestValidation(boolean) - Method in class org.apache.camel.model.rest.RestDefinition
 
cloneBuilder() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
cloneBuilder() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
cloneBuilder(DefaultErrorHandlerBuilder) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
cloneBuilder() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Clones this builder so each RouteBuilder has its private builder to use, to avoid changes from one RouteBuilder to influence the others.
cloneBuilder() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
cloneBuilder(ErrorHandlerBuilderRef) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
cloneBuilder(ErrorHandlerBuilderSupport) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
cloneBuilder() - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
closeCorrelationKeyOnCompletion(int) - Method in class org.apache.camel.model.AggregateDefinition
Closes a correlation key when its complete.
ClosedCorrelationKeyException - Exception in org.apache.camel.processor.aggregate
The correlation key has been closed and the Exchange cannot be aggregated.
ClosedCorrelationKeyException(String, Exchange) - Constructor for exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
ClosedCorrelationKeyException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
ClusteredRouteConfiguration - Class in org.apache.camel.impl.cluster
 
ClusteredRouteConfiguration() - Constructor for class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
ClusteredRouteController - Class in org.apache.camel.impl.cluster
 
ClusteredRouteController() - Constructor for class org.apache.camel.impl.cluster.ClusteredRouteController
 
ClusteredRouteFilter - Interface in org.apache.camel.impl.cluster
 
ClusteredRouteFilters - Class in org.apache.camel.impl.cluster
 
ClusteredRouteFilters.BlackList - Class in org.apache.camel.impl.cluster
 
ClusteredRouteFilters.IsAutoStartup - Class in org.apache.camel.impl.cluster
 
ClusteredRoutePolicy - Class in org.apache.camel.impl.cluster
 
ClusteredRoutePolicyFactory - Class in org.apache.camel.impl.cluster
 
ClusteredRoutePolicyFactory(String) - Constructor for class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
ClusteredRoutePolicyFactory(CamelClusterService.Selector, String) - Constructor for class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
ClusteredRoutePolicyFactory(CamelClusterService, String) - Constructor for class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
code(int) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
The response code such as a HTTP status code
code(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
The response code such as a HTTP status code.
collateExpression(String, int) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an iterator to collate (iterate) the given expression
CollectionFormat - Enum in org.apache.camel.model.rest
 
collectionFormat(CollectionFormat) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the collection format.
collectionFormat(CollectionFormat) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the collection format.
collectParameterAnnotations(Class<?>, Method) - Method in class org.apache.camel.component.bean.BeanInfo
 
collectParameterAnnotations(Class<?>, Method, List<Annotation>[]) - Method in class org.apache.camel.component.bean.BeanInfo
 
collisionAvoidanceFactor(double) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the collision avoidance factor
collisionAvoidanceFactor(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the collision avoidance factor (supports property placeholders)
collisionAvoidanceFactor(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the collision avoidance factor
collisionAvoidanceFactor(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the collision avoidance factor (supports property placeholders)
collisionAvoidanceFactor - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the collision avoidance percentage
collisionAvoidancePercent(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the collision avoidance percentage
collisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidance and sets the percentage used
combinedFilter() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
combinedFilter() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
CombinedServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
CombinedServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
CombinedServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
CombinedServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
CombinedServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
CombinedServiceCallServiceFilterConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
CombinedServiceDiscovery - Class in org.apache.camel.impl.cloud
 
CombinedServiceDiscovery(List<ServiceDiscovery>) - Constructor for class org.apache.camel.impl.cloud.CombinedServiceDiscovery
 
combinedServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
combinedServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
combinedServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
combinedServiceDiscovery(CombinedServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
combinedServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
CombinedServiceDiscoveryFactory - Class in org.apache.camel.impl.cloud
 
CombinedServiceDiscoveryFactory() - Constructor for class org.apache.camel.impl.cloud.CombinedServiceDiscoveryFactory
 
CombinedServiceFilter - Class in org.apache.camel.impl.cloud
 
CombinedServiceFilter(List<ServiceFilter>) - Constructor for class org.apache.camel.impl.cloud.CombinedServiceFilter
 
CombinedServiceFilterFactory - Class in org.apache.camel.impl.cloud
 
CombinedServiceFilterFactory() - Constructor for class org.apache.camel.impl.cloud.CombinedServiceFilterFactory
 
comment - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
commit() - Method in class org.apache.camel.impl.DefaultRouteContext
 
commit(Consumer, Endpoint, int) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
comparator(ExpressionResultComparator) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the comparator to use for stream resequencer
comparator(Comparator<T>) - Method in class org.apache.camel.model.SortDefinition
Sets the comparator to use for sorting
comparator() - Method in class org.apache.camel.processor.resequencer.Sequence
Returns this sequence's comparator.
comparatorRef(String) - Method in class org.apache.camel.model.SortDefinition
Sets a reference to lookup for the comparator to use for sorting
compare(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
compensation(String) - Method in class org.apache.camel.model.SagaDefinition
 
completeAllOnStop() - Method in class org.apache.camel.model.AggregateDefinition
Indicates to wait to complete all current and partial (pending) aggregated exchanges when the context is stopped.
completed - Variable in class org.apache.camel.main.MainSupport
 
completed() - Method in class org.apache.camel.main.MainSupport
Marks this process as being completed.
COMPLETED_BY_CONSUMER - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_FORCE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_INTERVAL - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_PREDICATE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_SIZE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_STRATEGY - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_TIMEOUT - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
completion() - Method in class org.apache.camel.model.AggregateDefinition
A Predicate to indicate when an aggregated exchange is complete.
completion(Predicate) - Method in class org.apache.camel.model.AggregateDefinition
A Predicate to indicate when an aggregated exchange is complete.
completion(String) - Method in class org.apache.camel.model.SagaDefinition
 
completionAware(FlexibleAggregationStrategy.CompletionAwareMixin) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Plugs in logic to execute when an aggregation batch completes.
completionEager(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets whether to complete the idempotent consumer eager or when the exchange is done.
completionFromBatchConsumer() - Method in class org.apache.camel.model.AggregateDefinition
Enables the batch completion mode where we aggregate from a BatchConsumer and aggregate the total number of exchanges the BatchConsumer has reported as total by checking the exchange property Exchange.BATCH_COMPLETE when its complete.
completionInterval(long) - Method in class org.apache.camel.model.AggregateDefinition
A repeating period in millis by which the aggregator will complete all current aggregated exchanges.
completionMode(SagaCompletionMode) - Method in class org.apache.camel.model.SagaDefinition
 
completionMode - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
completionMode(SagaCompletionMode) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
completionOnNewCorrelationGroup() - Method in class org.apache.camel.model.AggregateDefinition
Enables completion on all previous groups when a new incoming correlation group.
completionPredicate(Predicate) - Method in class org.apache.camel.model.AggregateDefinition
A Predicate to indicate when an aggregated exchange is complete.
completionPredicate() - Method in class org.apache.camel.model.AggregateDefinition
A Predicate to indicate when an aggregated exchange is complete.
completionSize(int) - Method in class org.apache.camel.model.AggregateDefinition
Number of messages aggregated before the aggregation is complete.
completionSize(Expression) - Method in class org.apache.camel.model.AggregateDefinition
Number of messages aggregated before the aggregation is complete.
completionTimeout(long) - Method in class org.apache.camel.model.AggregateDefinition
Time in millis that an aggregated exchange should be inactive before its complete (timeout).
completionTimeout(Expression) - Method in class org.apache.camel.model.AggregateDefinition
Time in millis that an aggregated exchange should be inactive before its complete (timeout).
completionTimeoutCheckerInterval(long) - Method in class org.apache.camel.model.AggregateDefinition
Interval in millis that is used by the background task that checks for timeouts (TimeoutMap).
component(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets the default Camel component to use for calling the remote service.
component(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the component to use
component(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific Camel rest component (consumer)
componentProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For additional configuration options on component level

The value can use # to refer to a bean to lookup in the registry.

CompositeNodes - Class in org.apache.camel.language.simple.ast
A node which contains other nodes.
CompositeNodes(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.CompositeNodes
 
concatExpression(Collection<Expression>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which returns the string concatenation value of the various expressions
concatExpression(Collection<Expression>, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which returns the string concatenation value of the various expressions
condition(Predicate) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Set a filter condition such as only results satisfying it will be aggregated.
configurationClasses - Variable in class org.apache.camel.main.MainSupport
 
configurations - Variable in class org.apache.camel.main.MainSupport
 
configure(RouteContext, ErrorHandler) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Configures the other error handler based on this error handler.
configure(RouteContext, ErrorHandler) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
configure() - Method in class org.apache.camel.builder.RouteBuilder
Called on initialization to build the routes using the fluent builder syntax.

This is a central method for RouteBuilder implementations to implement the routes using the Java fluent builder syntax.

configure(CamelContext) - Method in class org.apache.camel.builder.TransformerBuilder
Configure a Transformer according to the configurations built on this builder and register it into given CamelContext.
configure(CamelContext) - Method in class org.apache.camel.builder.ValidatorBuilder
Configures a new Validator according to the configurations built on this builder and register it into the given CamelContext.
configure(NamespaceAware) - Method in class org.apache.camel.builder.xml.Namespaces
Configures the namespace aware object
configure(CamelContext) - Method in interface org.apache.camel.main.MainListener
Callback to configure the created CamelContext.
configure(CamelContext) - Method in class org.apache.camel.main.MainListenerSupport
 
configureBuilder(XPathBuilder) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
configureChild(ProcessorDefinition<?>) - Method in class org.apache.camel.model.AggregateDefinition
 
configureChild(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ChoiceDefinition
 
configureChild(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ExpressionNode
 
configureChild(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ProcessorDefinition
Strategy for children to do any custom configuration
configureChild(ProcessorDefinition<?>) - Method in class org.apache.camel.reifier.ProcessorReifier
Strategy for children to do any custom configuration
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.ASN1DataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.AvroDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.BoonDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.IcalDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.LZFDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.UniVocityTsvDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.XmlRpcDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
 
configureDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.DataFormatDefinition
Allows derived classes to customize the data format
configureExchange(Exchange, ExchangePattern, Endpoint) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.SendProcessor
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.WireTapProcessor
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.JsonPathExpression
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.XPathExpression
 
configureExpression(CamelContext, Expression) - Method in class org.apache.camel.model.language.XQueryExpression
 
configureLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.LoadBalancerDefinition
Allows derived classes to customize the load balancer
configureNamespaceAware(Object) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.JsonPathExpression
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.XPathExpression
 
configurePredicate(CamelContext, Predicate) - Method in class org.apache.camel.model.language.XQueryExpression
 
configureProperties(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
configureRest(RestDefinition) - Method in class org.apache.camel.builder.RouteBuilder
 
configureRests(ModelCamelContext) - Method in class org.apache.camel.builder.RouteBuilder
Configures the rests
configureRoute(RouteDefinition) - Method in class org.apache.camel.builder.RouteBuilder
 
configureRoutes(ModelCamelContext) - Method in class org.apache.camel.builder.RouteBuilder
Configures the routes
configureSnakeDataFormat(DataFormat, CamelContext) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
confirm(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
connectionTimeout(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
connectTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Connect timeout for OkHttpClient
constant(Object) - Static method in class org.apache.camel.builder.Builder
Returns a constant expression
constant(Object) - Method in class org.apache.camel.builder.BuilderSupport
Returns a constant expression value builder
constant(Object) - Method in class org.apache.camel.builder.ExpressionClause
Specify the constant expression value.
constant(Object) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Specify the constant expression value.
constant(boolean) - Static method in class org.apache.camel.builder.PredicateBuilder
A constant predicate.
Constant - Annotation Type in org.apache.camel.language
Used to inject a constant expression into a field, property, method or parameter when using Bean Integration.
constant(Object) - Static method in class org.apache.camel.language.constant.ConstantLanguage
 
ConstantBeanHolder - Class in org.apache.camel.component.bean
A constant (singleton) bean implementation of BeanHolder
ConstantBeanHolder(Object, BeanInfo) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
ConstantBeanHolder(Object, CamelContext) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
ConstantBeanHolder(Object, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
constantExpression(Object) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the constant value
ConstantExpression - Class in org.apache.camel.model.language
To use a constant value in Camel expressions or predicates.
ConstantExpression() - Constructor for class org.apache.camel.model.language.ConstantExpression
 
ConstantExpression(String) - Constructor for class org.apache.camel.model.language.ConstantExpression
 
ConstantLanguage - Class in org.apache.camel.language.constant
A language for constant expressions.
ConstantLanguage() - Constructor for class org.apache.camel.language.constant.ConstantLanguage
 
Constants - Class in org.apache.camel.model
Various constants.
ConstantStaticTypeBeanHolder - Class in org.apache.camel.component.bean
A constant BeanHolder for a class or static class where the intention is to only invoke static methods, without the need for creating an instance of the type.
ConstantStaticTypeBeanHolder(Class<?>, CamelContext) - Constructor for class org.apache.camel.component.bean.ConstantStaticTypeBeanHolder
 
ConstantTypeBeanHolder - Class in org.apache.camel.component.bean
A constant (singleton) bean implementation of BeanTypeHolder
ConstantTypeBeanHolder(Class<?>, BeanInfo) - Constructor for class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
ConstantTypeBeanHolder(Class<?>, CamelContext) - Constructor for class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
ConstantTypeBeanHolder(Class<?>, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
ConsulServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
ConsulServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
ConsulServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
consulServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
consulServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
consulServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
consulServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
consulServiceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
consumerInjection(Method, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
consumerProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For additional configuration options on consumer level

The value can use # to refer to a bean to lookup in the registry.

consumes(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
contains(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
contains(Object) - Method in class org.apache.camel.builder.ValueBuilder
Create a predicate that the left hand expression contains the value of the right hand expression
contains(String) - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
containsIgnoreCase(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
containsKey(Object) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
containsSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
containsValue(Object) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
context - Variable in class org.apache.camel.impl.AbstractDynamicRegistry
 
contextPath(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets a leading context-path the REST services will be using.
ContextScanDefinition - Class in org.apache.camel.model
Scans for Java RouteBuilder instances in the context Registry.
ContextScanDefinition() - Constructor for class org.apache.camel.model.ContextScanDefinition
 
continued(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should handle and continue routing from the point of failure.
continued(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
continued(Expression) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
continueProcessing(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor
Strategy to determine if we should continue processing the Exchange.
continueProcessing(Exchange, String, Logger) - Static method in class org.apache.camel.processor.PipelineHelper
Should we continue processing the exchange?
continueProcessing(Exchange, AsyncProcessor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Strategy to determine if we should continue processing the Exchange.
continueRouting(Iterator<AsyncProcessor>, Exchange) - Method in class org.apache.camel.processor.Pipeline
 
continueRouting(Iterator<Processor>, Exchange) - Method in class org.apache.camel.processor.TryProcessor
 
ContractAdvice - Class in org.apache.camel.processor
A CamelInternalProcessorAdvice which applies Transformer and Validator according to the data type Contract.
ContractAdvice(Contract) - Constructor for class org.apache.camel.processor.ContractAdvice
 
convertBeanToEndpoint(String, Object) - Method in class org.apache.camel.impl.AbstractCamelContext
Strategy method for attempting to convert the bean from a Registry to an endpoint using some kind of transformation or wrapper
ConvertBodyDefinition - Class in org.apache.camel.model
Converts the message body to another type
ConvertBodyDefinition() - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(String) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(Class<?>) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(Class<?>, String) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyProcessor - Class in org.apache.camel.processor
A processor which converts the payload of the input message to be of the given type

If the conversion fails an InvalidPayloadException is thrown.

ConvertBodyProcessor(Class<?>) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
ConvertBodyProcessor(Class<?>, String) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
convertBodyTo(Class<?>) - Method in class org.apache.camel.model.ProcessorDefinition
Converts the IN message body to the specified type
convertBodyTo(Class<?>, String) - Method in class org.apache.camel.model.ProcessorDefinition
Converts the IN message body to the specified type
ConverterEntry() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterEntry
 
ConverterList() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterList
 
ConvertersAdapter() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ConvertersAdapter
 
convertTo(Class<?>) - Method in class org.apache.camel.builder.ValueBuilder
Converts the current value to the given type using the registered type converters
convertTo(Class<?>, Exchange, Object, TypeConverterRegistry) - Static method in class org.apache.camel.component.bean.BeanConverter
 
convertToExpression(Expression, Class<?>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which converts the given expression to the given type
convertToExpression(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which converts the given expression to the given type the type expression is evaluated to
convertToString() - Method in class org.apache.camel.builder.ValueBuilder
Converts the current value to a String using the registered type converters
copy() - Method in class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
copy() - Method in class org.apache.camel.model.LoopDefinition
Enables copy mode so a copy of the input Exchange is used for each iteration.
copy() - Method in class org.apache.camel.model.WireTapDefinition
Uses a copy of the original exchange
copy(boolean) - Method in class org.apache.camel.model.WireTapDefinition
Uses a copy of the original exchange
copy() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
copyExchangeStrategy(Processor, Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
Strategy method to copy the exchange before sending to another endpoint.
corePoolSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Core thread-pool size.
corsAllowCredentials(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Shortcut for setting the Access-Control-Allow-Credentials header.
corsHeaderProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For configuring CORS headers
countDown(Exchange, CountDownLatch) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
counter - Variable in class org.apache.camel.processor.SendProcessor
 
create() - Method in class org.apache.camel.builder.NotifyBuilder
Creates the expression this builder should use for matching.
create(CamelContext, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultManagementStrategyFactory
 
createAggregateExecutorService(String) - Method in class org.apache.camel.processor.MulticastProcessor
Strategy to create the thread pool for the aggregator background task which waits for and aggregates completed tasks when running in parallel mode.
createAggregationStrategy() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
createAndSetExpression(T) - Static method in class org.apache.camel.builder.ExpressionClause
 
createAsyncProcessorAwaitManager() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createAsyncProcessorAwaitManager() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createAsyncProducer() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createBeanInfo(Class<?>) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
createBeanInfo(Object) - Method in class org.apache.camel.component.bean.RegistryBean
 
createBeanPostProcessor() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createBeanPostProcessor() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default bean post processor
createBodyAndHeaderProcessor(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createBodyAndPropertyProcessor(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createCacheHolder() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
Creates a cached and constant BeanHolder from this holder.
createCacheHolder() - Method in class org.apache.camel.component.bean.RegistryBean
Creates a cached and constant BeanHolder from this holder.
createCamelContext() - Method in class org.apache.camel.main.Main
 
createCamelContext() - Method in class org.apache.camel.main.MainSupport
 
createCamelContextNameStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createCamelContextNameStrategy() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createChannel(RouteContext) - Method in class org.apache.camel.reifier.ProcessorReifier
Creates a new instance of the Channel.
createChildProcessor(RouteContext, NamedNode, boolean) - Method in class org.apache.camel.impl.DefaultProcessorFactory
 
createChildProcessor(RouteContext, NamedNode, boolean) - Method in class org.apache.camel.impl.TypedProcessorFactory
 
createChildProcessor(RouteContext, boolean) - Method in class org.apache.camel.reifier.ProcessorReifier
Creates the child processor (outputs) from the current definition
createChildUnitOfWork(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
createClassResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createClassResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createCompletionFunction(Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createComponentResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createComponentResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createCompositeProcessor(RouteContext, List<Processor>) - Method in class org.apache.camel.reifier.ProcessorReifier
Creates a new instance of some kind of composite processor which defaults to using a Pipeline but derived classes could change the behaviour
createConsumer(Processor) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createConsumerTemplate() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createConsumerTemplate(int) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createConvertBodyProcessor(Class<?>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createDataFormat(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.DefaultDataFormatResolver
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.BoonDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.CustomDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.GzipDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.SerializationDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.ZipDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.DataFormatDefinition
Factory method to create the data format instance
createDataFormatResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createDataFormatResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createDebugger(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogDebugger
Creates a new backlog debugger.
createDefaultExceptionPolicyStrategy() - Static method in class org.apache.camel.processor.ErrorHandlerSupport
Creates the default exception policy strategy to use.
createDefaultFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
createDefaultXPathFactory() - Static method in class org.apache.camel.builder.xml.XPathBuilder
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.bean.BeanComponent
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.beanclass.ClassComponent
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetComponent
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.mock.MockComponent
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.test.TestComponent
 
createEndpoint(String) - Method in class org.apache.camel.impl.AbstractCamelContext
A pluggable strategy to allow an endpoint to be created without requiring a component to be its factory, such as for looking up the URI inside some Registry
createEndpointRegistry(Map<EndpointKey, Endpoint>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createEndpointRegistry(Map<EndpointKey, Endpoint>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
createEndpointUri() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
createErrorHandler(RouteContext, Exchange, Processor) - Method in class org.apache.camel.processor.MulticastProcessor
 
createErrorHandler(RouteContext, Exchange, AsyncProcessor, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
createErrorHandlerBuilder() - Method in class org.apache.camel.builder.BuilderSupport
 
createErrorHandlerExecutorService() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createExceptionIterator(Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy method creating the iterator to walk the exception in the order Camel should use for find the OnExceptionDefinition should be used.
createExchange(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Creates a message exchange for the given index in the DataSet
createExchange() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createExecutorServiceManager() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createExecutorServiceManager() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createExpression(CamelContext) - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class<?>) - Method in interface org.apache.camel.component.bean.AnnotationExpressionFactory
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class<?>) - Method in class org.apache.camel.component.bean.BeanAnnotationExpressionFactory
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class<?>) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class<?>) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
createExpression(String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createExpression(Object, String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createExpression(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createExpression(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createExpression(String) - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
createExpression(String) - Method in class org.apache.camel.language.ref.RefLanguage
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.NullExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionExpression
Creates a Camel Expression based on this model.
createExpression(String, boolean) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionExpression
Creates a Camel Expression based on this model.
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
createExpression(String) - Method in interface org.apache.camel.language.simple.ast.SimpleNode
Creates a Camel Expression based on this model.
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SingleQuoteEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createExpression(String, Class<?>) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createExpression() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
Creates a tokenize expression.
createExpression(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createExpression() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
Creates a tokenize expression.
createExpression(String) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
createExpression(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
createExpression(RouteContext) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.JsonPathExpression
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.SimpleExpression
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.TokenizerExpression
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.XPathExpression
 
createExpression(CamelContext) - Method in class org.apache.camel.model.language.XQueryExpression
 
createFactoryFinder(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createFactoryFinderResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createFactoryFinderResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createFluentProducerTemplate() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createFluentProducerTemplate(int) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createHeadersMapFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createHeadersMapFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createHealthCheckRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createHealthCheckRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createId(NamedNode) - Method in class org.apache.camel.impl.DefaultNodeIdFactory
 
createId(NamedNode) - Method in class org.apache.camel.impl.RouteIdFactory
 
createInflightRepository() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createInflightRepository() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createInjectionConsumerTemplate(String, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a ConsumerTemplate to be injected into a POJO
createInjectionFluentProducerTemplate(String, String, String, Object) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a FluentProducerTemplate to be injected into a POJO
createInjectionPollingConsumer(Endpoint, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a started PollingConsumer to be injected into a POJO
createInjectionProducer(Endpoint, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
A Factory method to create a started Producer to be injected into a POJO
createInjectionProducerTemplate(String, String, String, Object) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a ProducerTemplate to be injected into a POJO
createInjector() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createInjector() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createInvocation(Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInfo
 
createIterator(Exchange, InputStream, String) - Method in class org.apache.camel.builder.TokenPairExpressionIterator
Strategy to create the iterator
createIterator(Exchange, InputStream, String) - Method in class org.apache.camel.builder.TokenXMLExpressionIterator
 
createIterator(InputStream, String) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
createIterator(Reader) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
createLanguageResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createLanguageResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createLifecycle(CamelContext) - Method in class org.apache.camel.impl.DefaultManagementStrategyFactory
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.reifier.loadbalancer.LoadBalancerReifier
Factory method to create the load balancer from the loadBalancerTypeName
createLogger() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createLogger() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createLruCache(int) - Static method in class org.apache.camel.component.bean.MethodInfoCache
 
createManagementNameStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createManagementNameStrategy() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createManagementObjectNameStrategy(String) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
createManagementObjectStrategy() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
createMessageBody(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
createMessageBody(long) - Method in class org.apache.camel.component.dataset.ListDataSet
Creates the message body for a given message.
createMessageBody(long) - Method in class org.apache.camel.component.dataset.SimpleDataSet
Creates the message body for a given message
createMessageHistoryFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createMessageHistoryFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createMethodInfo(Class<?>, Method) - Method in class org.apache.camel.component.bean.BeanInfo
 
createMethodInfo(Method) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
createMethodInfo() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanInfo
 
createMethodInfoCache(Endpoint) - Static method in class org.apache.camel.component.bean.ProxyHelper
 
createMethodInvocation(Object, boolean, Exchange) - Method in class org.apache.camel.component.bean.MethodInfo
 
createModelFromXml(CamelContext, String, Class<T>) - Static method in class org.apache.camel.model.ModelHelper
Marshal the xml to the model definition
createModelFromXml(CamelContext, InputStream, Class<T>) - Static method in class org.apache.camel.model.ModelHelper
Marshal the xml to the model definition
createModelJAXBContextFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createModelJAXBContextFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createMulticast(Collection<Processor>, ExecutorService, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createNamespaceContext(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
createNextExchange(Exchange) - Static method in class org.apache.camel.processor.PipelineHelper
Strategy method to create the next exchange from the previous exchange.
createNodeIdFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createNodeIdFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createOptimisticLockRetryPolicy() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
createOutputsProcessor(RouteContext) - Method in class org.apache.camel.reifier.ProcessorReifier
Prefer to use {#link #createChildProcessor}.
createOutputsProcessor(RouteContext, Collection<ProcessorDefinition<?>>) - Method in class org.apache.camel.reifier.ProcessorReifier
 
createOutputsProcessorImpl(RouteContext, Collection<ProcessorDefinition<?>>) - Method in class org.apache.camel.reifier.ProcessorReifier
 
createPackageScanClassResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createPackageScanClassResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createParameterExpressions() - Method in class org.apache.camel.component.bean.MethodInfo
 
createParameterMappingStrategy(CamelContext) - Static method in class org.apache.camel.component.bean.BeanInfo
 
createParameterMappingStrategy() - Method in class org.apache.camel.component.bean.RegistryBean
 
createParametersExpression() - Method in class org.apache.camel.component.bean.MethodInfo
 
createPollingConsumer() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createPollingConsumerServicePool() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createPollingConsumerServicePool() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createPredicate(String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.ref.RefLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createPredicate(CamelContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createPredicate(CamelContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createPredicate(CamelContext) - Method in class org.apache.camel.model.language.SimpleExpression
 
createPredicate(CamelContext) - Method in class org.apache.camel.model.language.TokenizerExpression
 
createPredicate(CamelContext) - Method in class org.apache.camel.model.language.XPathExpression
 
createProcessor(RouteContext, NamedNode) - Method in class org.apache.camel.impl.DefaultProcessorFactory
 
createProcessor(RouteContext, NamedNode) - Method in class org.apache.camel.impl.TypedProcessorFactory
 
createProcessor(RouteContext) - Method in class org.apache.camel.reifier.ProcessorReifier
Override this in definition class and implement logic to create the processor based on the definition model.
createProcessor(RouteContext, ProcessorDefinition<?>) - Method in class org.apache.camel.reifier.ProcessorReifier
 
createProcessor(RouteContext) - Method in class org.apache.camel.reifier.RouteReifier
 
createProcessor(RouteContext) - Method in class org.apache.camel.reifier.TransactedReifier
 
createProcessorExchangePair(int, Processor, Exchange, RouteContext) - Method in class org.apache.camel.processor.MulticastProcessor
Creates the ProcessorExchangePair which holds the processor and exchange to be send out.
createProcessorExchangePair(int, Endpoint, Producer, Exchange, ExchangePattern) - Method in class org.apache.camel.processor.RecipientListProcessor
This logic is similar to MulticastProcessor but we have to return a RecipientProcessorExchangePair instead
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.RecipientListProcessor
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.Splitter
 
createProcessorFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createProcessorFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createProducer() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
createProducer() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createProducer() - Method in class org.apache.camel.component.mock.MockEndpoint
 
createProducer() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
createProducer(Endpoint) - Static method in class org.apache.camel.processor.DeferServiceFactory
Creates the Producer which is deferred started until CamelContext is being started.
createProducerServicePool() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createProducerServicePool() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createProducerTemplate() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createProducerTemplate(int) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createPropertyPlaceholdersChangeReverter() - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Creates a Runnable which when run will revert property placeholder updates to the camel route definitions that were done after this method is called.
createProxy(Endpoint, Class<?>...) - Static method in class org.apache.camel.component.bean.PojoProxyHelper
 
createProxy(Endpoint, boolean, ClassLoader, Class<T>, MethodInfoCache) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, boolean, ClassLoader, Class<T>[], MethodInfoCache) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, ClassLoader, Class<T>) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, boolean, ClassLoader, Class<T>...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, Class<T>) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, boolean, Class<T>...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, Producer, Class<T>) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxy(Endpoint, boolean, Producer, Class<T>...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createProxyInstantiationRuntimeException(Class<?>, Endpoint, Exception) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
createProxyObject(Endpoint, boolean, Producer, ClassLoader, Class<T>[], MethodInfoCache) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends the exchange to the endpoint.
createRedeliveryPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createRedeliveryPolicy(RedeliveryPolicyDefinition, CamelContext, RedeliveryPolicy) - Static method in class org.apache.camel.reifier.ErrorHandlerReifier
 
createRedeliveryPolicy(OnExceptionDefinition, CamelContext, RedeliveryPolicy) - Static method in class org.apache.camel.reifier.ErrorHandlerReifier
Allows an exception handler to create a new redelivery policy for this exception type
createRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createReporter() - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
createReporter() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createResourceExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.Enricher
Creates a new DefaultExchange instance from the given exchange.
createRest() - Method in class org.apache.camel.model.rest.RestsDefinition
 
createRestBindingAdvice(RouteContext) - Method in class org.apache.camel.reifier.rest.RestBindingReifier
 
createRestRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRestRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createRoute() - Method in class org.apache.camel.model.RoutesDefinition
 
createRouteBuilder(CamelContext) - Method in class org.apache.camel.model.RouteBuilderDefinition
 
createRouteController() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRouteController() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createRoutePolicy(CamelContext, String, NamedNode) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicyFactory
 
createRoutePolicy(CamelContext, String, NamedNode) - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
createRoutePolicy(CamelContext, String, NamedNode) - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
 
createRoutes(CamelContext) - Method in class org.apache.camel.model.RouteBuilderDefinition
 
createRouteStaticEndpointJson(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRouteStaticEndpointJson(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRoutingSlipIterator(Exchange, Expression) - Method in class org.apache.camel.processor.DynamicRouter
 
createRoutingSlipIterator(Exchange, Expression) - Method in class org.apache.camel.processor.RoutingSlip
Creates the route slip iterator to be used.
createRuntimeCamelCatalog() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createRuntimeCamelCatalog() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createSet(Expression, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSet(Comparator<? super Exchange>, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSetBodyProcessor(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createShutdownStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createShutdownStrategy() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createStreamCachingStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createStreamCachingStrategy() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createTraceNamespaceExpression() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
createTracer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogTracer
Creates a new backlog tracer.
createTransformer(CamelContext) - Method in class org.apache.camel.reifier.transformer.TransformerReifier
 
createTransformerRegistry(List<TransformerDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createTransformerRegistry(List<TransformerDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
createTypeConverter() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createTypeConverter() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createTypeConverterRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createTypeConverterRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWorkFactory
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
createUnitOfWorkFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createUnitOfWorkFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createUnitOfWorkProcessor(RouteContext, Processor, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Strategy to create the unit of work to be used for the sub route
createUuidGenerator() - Method in class org.apache.camel.impl.AbstractCamelContext
 
createUuidGenerator() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createValidator(CamelContext) - Method in class org.apache.camel.reifier.validator.ValidatorReifier
 
createValidatorRegistry(List<ValidatorDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
createValidatorRegistry(List<ValidatorDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
createXPathExpression() - Method in class org.apache.camel.builder.xml.XPathBuilder
Creates a new xpath expression as there we no available in the pool.
createXPathFactory() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
CryptoDataFormat - Class in org.apache.camel.model.dataformat
Crypto data format is used for encrypting and decrypting of messages using Java Cryptographic Extension.
CryptoDataFormat() - Constructor for class org.apache.camel.model.dataformat.CryptoDataFormat
 
csv() - Method in class org.apache.camel.builder.DataFormatClause
Uses the CSV data format
CsvDataFormat - Class in org.apache.camel.model.dataformat
The CSV data format is used for handling CSV payloads.
CsvDataFormat() - Constructor for class org.apache.camel.model.dataformat.CsvDataFormat
 
CsvDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.CsvDataFormat
 
CsvDataFormat(boolean) - Constructor for class org.apache.camel.model.dataformat.CsvDataFormat
 
csvLazyLoad() - Method in class org.apache.camel.builder.DataFormatClause
Uses the CSV data format for a huge file.
currentIndex - Variable in class org.apache.camel.component.mock.AssertionClause
 
currentSystemTime() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
custom(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the custom data format
custom(String) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
custom(ServiceFilter) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
custom(String) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses the custom load balancer
CustomDataFormat - Class in org.apache.camel.model.dataformat
To use a custom data format implementation that does not come out of the box from Apache Camel.
CustomDataFormat() - Constructor for class org.apache.camel.model.dataformat.CustomDataFormat
 
CustomDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.CustomDataFormat
 
customExchangeFormatter - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
customFilter(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
customFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
customFilter(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
customFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
CustomLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Custom load balancer
CustomLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
 
customResolveManagementName(String, String) - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
Strategy to do any custom resolution of the name
customResolveManagementName(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
customResourceLocator(URL) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
CustomServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
CustomServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
 
CustomServiceCallServiceFilterConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
 
CustomTransformerDefinition - Class in org.apache.camel.model.transformer
Represents a CustomTransformer.
CustomTransformerDefinition() - Constructor for class org.apache.camel.model.transformer.CustomTransformerDefinition
 
CustomValidatorDefinition - Class in org.apache.camel.model.validator
Represents a CustomValidator.
CustomValidatorDefinition() - Constructor for class org.apache.camel.model.validator.CustomValidatorDefinition
 

D

dataCenter(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The data center
dataFormat(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
The data format of the parameter such as binary, date, date-time, password.
dataFormat(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
The data format of the parameter such as binary, date, date-time, password.
DATAFORMAT_RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultDataFormatResolver
 
DataFormatClause<T extends ProcessorDefinition<?>> - Class in org.apache.camel.builder
An expression for constructing the different possible DataFormat options.
DataFormatClause(T, DataFormatClause.Operation) - Constructor for class org.apache.camel.builder.DataFormatClause
 
DataFormatClause.Operation - Enum in org.apache.camel.builder
DataFormat operations.
DataFormatDefinition - Class in org.apache.camel.model
Represents a Camel data format
DataFormatDefinition() - Constructor for class org.apache.camel.model.DataFormatDefinition
 
DataFormatDefinition(DataFormat) - Constructor for class org.apache.camel.model.DataFormatDefinition
 
DataFormatDefinition(String) - Constructor for class org.apache.camel.model.DataFormatDefinition
 
dataFormatProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For additional configuration options on data format level

The value can use # to refer to a bean to lookup in the registry.

DataFormatsDefinition - Class in org.apache.camel.model.dataformat
To configure data formats
DataFormatsDefinition() - Constructor for class org.apache.camel.model.dataformat.DataFormatsDefinition
 
DataFormatTransformer - Class in org.apache.camel.impl.transformer
A Transformer implementation which leverages DataFormat to perform transformation.
DataFormatTransformer(CamelContext) - Constructor for class org.apache.camel.impl.transformer.DataFormatTransformer
 
DataFormatTransformerDefinition - Class in org.apache.camel.model.transformer
Represents a DataFormatTransformer which leverages DataFormat to perform transformation.
DataFormatTransformerDefinition() - Constructor for class org.apache.camel.model.transformer.DataFormatTransformerDefinition
 
DataSet - Interface in org.apache.camel.component.dataset
Represents a strategy for testing endpoints with canned data.
DataSetComponent - Class in org.apache.camel.component.dataset
Component for DataSet.
DataSetComponent() - Constructor for class org.apache.camel.component.dataset.DataSetComponent
 
DataSetConsumer - Class in org.apache.camel.component.dataset
DataSet consumer.
DataSetConsumer(DataSetEndpoint, Processor) - Constructor for class org.apache.camel.component.dataset.DataSetConsumer
 
DataSetEndpoint - Class in org.apache.camel.component.dataset
The dataset component provides a mechanism to easily perform load & soak testing of your system.
DataSetEndpoint(String, Component, DataSet) - Constructor for class org.apache.camel.component.dataset.DataSetEndpoint
 
DataSetSupport - Class in org.apache.camel.component.dataset
Base class for DataSet
DataSetSupport() - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
DataSetSupport(int) - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
dataType(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
The data type of the parameter such as string, integer, boolean
dataType(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
The data type of the header such as string, integer, boolean
dateExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
dateExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
dateExpression(String, String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
deadLetter - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
deadLetter - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
deadLetterChannel(String) - Method in class org.apache.camel.builder.BuilderSupport
Dead Letter Channel EIP: is a error handler for handling messages that could not be delivered to it's intended destination.
deadLetterChannel(Endpoint) - Method in class org.apache.camel.builder.BuilderSupport
Dead Letter Channel EIP: is a error handler for handling messages that could not be delivered to it's intended destination.
DeadLetterChannel - Class in org.apache.camel.processor
Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
DeadLetterChannel(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, ExceptionPolicyStrategy, Processor, String, boolean, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.DeadLetterChannel
Creates the dead letter channel.
DeadLetterChannelBuilder - Class in org.apache.camel.builder
A builder of a Dead Letter Channel
DeadLetterChannelBuilder() - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(Endpoint) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(String) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
deadLetterHandleNewException - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
deadLetterHandleNewException(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Whether the dead letter channel should handle (and ignore) any new exception that may been thrown during sending the message to the dead letter endpoint.
deadLetterHandleNewException - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
deadLetterUri - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
deadLetterUri - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
Debug - Class in org.apache.camel.processor.interceptor
A debug interceptor to notify Debugger with Exchanges being processed.
Debug(Debugger) - Constructor for class org.apache.camel.processor.interceptor.Debug
 
decrement() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
decrementSum() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.camel.processor.Resequencer
 
DEFAULT_BATCH_TIMEOUT - Static variable in class org.apache.camel.processor.Resequencer
 
DEFAULT_COMPONENT - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_DELIMITER - Static variable in class org.apache.camel.model.DynamicRouterDefinition
 
DEFAULT_DELIMITER - Static variable in class org.apache.camel.model.RoutingSlipDefinition
 
DEFAULT_ERROR_HANDLER_BUILDER - Static variable in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
DEFAULT_EXIT_CODE - Static variable in class org.apache.camel.main.MainSupport
 
DEFAULT_GROUP_KEY - Static variable in class org.apache.camel.model.HystrixConfigurationDefinition
 
DEFAULT_LOAD_BALANCER_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
DEFAULT_REST_CONFIGURATION_ID - Static variable in class org.apache.camel.model.rest.RestConstants
 
DEFAULT_SELECTOR - Static variable in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
DEFAULT_SERVICE_CALL_CONFIG_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_SERVICE_CALL_EXPRESSION_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_SERVICE_CHOOSER_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_SERVICE_DISCOVERY_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DEFAULT_SERVICE_FILTER_ID - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
DefaultAggregateController - Class in org.apache.camel.processor.aggregate
A default AggregateController that offers Java and JMX API.
DefaultAggregateController() - Constructor for class org.apache.camel.processor.aggregate.DefaultAggregateController
 
DefaultAnnotationExpressionFactory - Class in org.apache.camel.component.bean
Default implementation of the AnnotationExpressionFactory.
DefaultAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
DefaultAsyncProcessorAwaitManager - Class in org.apache.camel.impl
 
DefaultAsyncProcessorAwaitManager() - Constructor for class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
DefaultBacklogTracerEventMessage - Class in org.apache.camel.processor.interceptor
An event message holding the traced message by the BacklogTracer.
DefaultBacklogTracerEventMessage(long, Date, String, String, String, String) - Constructor for class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
DefaultCamelBeanPostProcessor - Class in org.apache.camel.impl
A bean post processor which implements the Bean Integration features in Camel.
DefaultCamelBeanPostProcessor() - Constructor for class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
DefaultCamelBeanPostProcessor(CamelContext) - Constructor for class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
DefaultCamelContext - Class in org.apache.camel.impl
Represents the context used to configure routes and the policies to use.
DefaultCamelContext() - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext using DefaultRegistry as registry.
DefaultCamelContext(BeanRepository) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext using the given BeanRepository as first-choice repository, and the SimpleRegistry as fallback, via the DefaultRegistry implementation.
DefaultCamelContext(Context) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Deprecated.
create a new JndiRegistry and use the constructor that accepts this registry.
DefaultCamelContext(Registry) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext using the given registry
DefaultCamelContext(boolean) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext and allows to control whether the context should automatic initialize or not.
DefaultCamelContextNameStrategy - Class in org.apache.camel.impl
A default name strategy which auto assigns a name using a prefix-counter pattern.
DefaultCamelContextNameStrategy() - Constructor for class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
DefaultCamelContextNameStrategy(String) - Constructor for class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
DefaultChannel - Class in org.apache.camel.processor.interceptor
DefaultChannel is the default Channel.
DefaultChannel() - Constructor for class org.apache.camel.processor.interceptor.DefaultChannel
 
DefaultClaimCheckRepository - Class in org.apache.camel.impl
The default ClaimCheckRepository implementation that is an in-memory storage.
DefaultClaimCheckRepository() - Constructor for class org.apache.camel.impl.DefaultClaimCheckRepository
 
DefaultClassResolver - Class in org.apache.camel.impl
Default class resolver that uses regular class loader to load classes.
DefaultClassResolver() - Constructor for class org.apache.camel.impl.DefaultClassResolver
 
DefaultClassResolver(CamelContext) - Constructor for class org.apache.camel.impl.DefaultClassResolver
 
defaultCompletionMode() - Static method in enum org.apache.camel.model.SagaCompletionMode
 
DefaultComponentResolver - Class in org.apache.camel.impl
The default implementation of ComponentResolver which tries to find components by using the URI scheme prefix and searching for a file of the URI scheme name in the META-INF/services/org/apache/camel/component/ directory on the classpath.
DefaultComponentResolver() - Constructor for class org.apache.camel.impl.DefaultComponentResolver
 
DefaultConsumerCache - Class in org.apache.camel.impl
Cache containing created Consumer.
DefaultConsumerCache(Object, CamelContext, int) - Constructor for class org.apache.camel.impl.DefaultConsumerCache
 
DefaultConsumerTemplate - Class in org.apache.camel.impl
Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and consuming Message instances in an Exchange from an Endpoint.
DefaultConsumerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.DefaultConsumerTemplate
 
DefaultDataFormatResolver - Class in org.apache.camel.impl
Default data format resolver
DefaultDataFormatResolver() - Constructor for class org.apache.camel.impl.DefaultDataFormatResolver
 
DefaultDebugger - Class in org.apache.camel.impl
The default implementation of the Debugger.
DefaultDebugger() - Constructor for class org.apache.camel.impl.DefaultDebugger
 
DefaultDebugger(CamelContext) - Constructor for class org.apache.camel.impl.DefaultDebugger
 
DefaultEndpointRegistry - Class in org.apache.camel.impl
Default implementation of EndpointRegistry
DefaultEndpointRegistry(CamelContext) - Constructor for class org.apache.camel.impl.DefaultEndpointRegistry
 
DefaultEndpointRegistry(CamelContext, Map<EndpointKey, Endpoint>) - Constructor for class org.apache.camel.impl.DefaultEndpointRegistry
 
DefaultEndpointUtilizationStatistics - Class in org.apache.camel.impl
 
DefaultEndpointUtilizationStatistics(int) - Constructor for class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
defaultErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
Creates a default error handler.
DefaultErrorHandler - Class in org.apache.camel.processor
Default error handler
DefaultErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, ExceptionPolicyStrategy, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.DefaultErrorHandler
Creates the default error handler.
DefaultErrorHandlerBuilder - Class in org.apache.camel.builder
The default error handler builder.
DefaultErrorHandlerBuilder() - Constructor for class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
DefaultExceptionPolicyStrategy - Class in org.apache.camel.processor.exceptionpolicy
The default strategy used in Camel to resolve the OnExceptionDefinition that should handle the thrown exception.
DefaultExceptionPolicyStrategy() - Constructor for class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
 
DefaultExchangeComparator - Class in org.apache.camel.processor.resequencer
Compares elements of an Exchange sequence by comparing long values returned by this comparator's expression.
DefaultExchangeComparator() - Constructor for class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
DefaultExecutorServiceManager - Class in org.apache.camel.impl
Default ExecutorServiceManager.
DefaultExecutorServiceManager(CamelContext) - Constructor for class org.apache.camel.impl.DefaultExecutorServiceManager
 
DefaultFactoryFinder - Class in org.apache.camel.impl
Default factory finder.
DefaultFactoryFinder(ClassResolver, String) - Constructor for class org.apache.camel.impl.DefaultFactoryFinder
 
DefaultFactoryFinder.ClassSupplier - Interface in org.apache.camel.impl
 
DefaultFactoryFinderResolver - Class in org.apache.camel.impl
Default factory finder.
DefaultFactoryFinderResolver() - Constructor for class org.apache.camel.impl.DefaultFactoryFinderResolver
 
DefaultFluentProducerTemplate - Class in org.apache.camel.builder
 
DefaultFluentProducerTemplate(CamelContext) - Constructor for class org.apache.camel.builder.DefaultFluentProducerTemplate
 
DefaultHeadersMapFactory - Class in org.apache.camel.impl
Default HeadersMapFactory which uses the CaseInsensitiveMap.
DefaultHeadersMapFactory() - Constructor for class org.apache.camel.impl.DefaultHeadersMapFactory
 
DefaultInflightRepository - Class in org.apache.camel.impl
Default InflightRepository.
DefaultInflightRepository() - Constructor for class org.apache.camel.impl.DefaultInflightRepository
 
DefaultInjector - Class in org.apache.camel.impl
A default implementation of Injector which just uses reflection to instantiate new objects using their zero argument constructor, and then performing bean post processing using DefaultCamelBeanPostProcessor.
DefaultInjector(CamelContext) - Constructor for class org.apache.camel.impl.DefaultInjector
 
DefaultInterceptSendToEndpoint - Class in org.apache.camel.impl
This is an endpoint when sending to it, is intercepted and is routed in a detour
DefaultInterceptSendToEndpoint(Endpoint, boolean) - Constructor for class org.apache.camel.impl.DefaultInterceptSendToEndpoint
Intercepts sending to the given endpoint
DefaultLanguageResolver - Class in org.apache.camel.impl
Default language resolver that looks for language factories in META-INF/services/org/apache/camel/language/ and language resolvers in META-INF/services/org/apache/camel/language/resolver/.
DefaultLanguageResolver() - Constructor for class org.apache.camel.impl.DefaultLanguageResolver
 
defaultLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
defaultLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
DefaultManagementNameStrategy - Class in org.apache.camel.impl
Default implementation of ManagementNameStrategy

This implementation will by default use a name pattern as #name# and in case of a clash, then the pattern will fallback to be using the counter as #name#-#counter#.

DefaultManagementNameStrategy(CamelContext) - Constructor for class org.apache.camel.impl.DefaultManagementNameStrategy
 
DefaultManagementNameStrategy(CamelContext, String, String) - Constructor for class org.apache.camel.impl.DefaultManagementNameStrategy
 
DefaultManagementStrategy - Class in org.apache.camel.impl
A default management strategy that does not manage.
DefaultManagementStrategy() - Constructor for class org.apache.camel.impl.DefaultManagementStrategy
 
DefaultManagementStrategy(CamelContext) - Constructor for class org.apache.camel.impl.DefaultManagementStrategy
 
DefaultManagementStrategy(CamelContext, ManagementAgent) - Constructor for class org.apache.camel.impl.DefaultManagementStrategy
 
DefaultManagementStrategyFactory - Class in org.apache.camel.impl
Factory for creating non JMX ManagementStrategy.
DefaultManagementStrategyFactory() - Constructor for class org.apache.camel.impl.DefaultManagementStrategyFactory
 
DefaultMessageHistoryFactory - Class in org.apache.camel.impl
 
DefaultMessageHistoryFactory() - Constructor for class org.apache.camel.impl.DefaultMessageHistoryFactory
 
DefaultModelJAXBContextFactory - Class in org.apache.camel.impl
Default implementation of ModelJAXBContextFactory.
DefaultModelJAXBContextFactory() - Constructor for class org.apache.camel.impl.DefaultModelJAXBContextFactory
 
DefaultNamespaceContext - Class in org.apache.camel.builder.xml
An implementation of NamespaceContext which uses a simple Map where the keys are the prefixes and the values are the URIs
DefaultNamespaceContext() - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultNamespaceContext(XPathFactory) - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultNamespaceContext(NamespaceContext, Map<String, String>) - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultNodeIdFactory - Class in org.apache.camel.impl
Default id factory.
DefaultNodeIdFactory() - Constructor for class org.apache.camel.impl.DefaultNodeIdFactory
 
DefaultPackageScanClassResolver - Class in org.apache.camel.impl
Default implement of PackageScanClassResolver
DefaultPackageScanClassResolver() - Constructor for class org.apache.camel.impl.DefaultPackageScanClassResolver
 
DefaultParameterMappingStrategy - Class in org.apache.camel.component.bean
Represents the strategy used to figure out how to map a message exchange to a POJO method invocation
DefaultParameterMappingStrategy() - Constructor for class org.apache.camel.component.bean.DefaultParameterMappingStrategy
 
DefaultProcessorFactory - Class in org.apache.camel.impl
Default ProcessorFactory that supports using 3rd party Camel components to implement the EIP Processor.
DefaultProcessorFactory() - Constructor for class org.apache.camel.impl.DefaultProcessorFactory
 
DefaultProducerCache - Class in org.apache.camel.impl
Cache containing created Producer.
DefaultProducerCache(Object, CamelContext, int) - Constructor for class org.apache.camel.impl.DefaultProducerCache
 
DefaultProducerTemplate - Class in org.apache.camel.impl
Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
DefaultProducerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, ExecutorService) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, Endpoint) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
defaultProfile(Boolean) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
DefaultRestRegistry - Class in org.apache.camel.impl
 
DefaultRestRegistry() - Constructor for class org.apache.camel.impl.DefaultRestRegistry
 
DefaultRoute - Class in org.apache.camel.impl
Default implementation of Route.
DefaultRoute(RouteContext, Endpoint) - Constructor for class org.apache.camel.impl.DefaultRoute
 
DefaultRoute(RouteContext, Endpoint, Service...) - Constructor for class org.apache.camel.impl.DefaultRoute
 
DefaultRouteContext - Class in org.apache.camel.impl
The context used to activate new routing rules
DefaultRouteContext(CamelContext, RouteDefinition, FromDefinition, Collection<Route>) - Constructor for class org.apache.camel.impl.DefaultRouteContext
 
DefaultRouteContext(CamelContext) - Constructor for class org.apache.camel.impl.DefaultRouteContext
Only used for lazy construction from inside ExpressionType
DefaultRouteController - Class in org.apache.camel.impl
 
DefaultRouteController() - Constructor for class org.apache.camel.impl.DefaultRouteController
 
DefaultRouteController(DefaultCamelContext) - Constructor for class org.apache.camel.impl.DefaultRouteController
 
DefaultRouteError - Class in org.apache.camel.impl
 
DefaultRouteError(RouteError.Phase, Throwable) - Constructor for class org.apache.camel.impl.DefaultRouteError
 
DefaultRouteStartupOrder - Class in org.apache.camel.impl
Default implementation of RouteStartupOrder.
DefaultRouteStartupOrder(int, Route, RouteService) - Constructor for class org.apache.camel.impl.DefaultRouteStartupOrder
 
DefaultRuntimeEndpointRegistry - Class in org.apache.camel.impl
 
DefaultRuntimeEndpointRegistry() - Constructor for class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
defaultSelector() - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
DefaultServiceCallExpression - Class in org.apache.camel.impl.cloud
Support class for custom implementations of ServiceCall EIP components.
DefaultServiceCallExpression() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceCallExpression
 
DefaultServiceCallExpression(String, String) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceCallExpression
 
DefaultServiceCallProcessor - Class in org.apache.camel.impl.cloud
 
DefaultServiceCallProcessor(CamelContext, String, String, String, ExchangePattern, ServiceLoadBalancer, Expression) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
DefaultServiceCallServiceLoadBalancerConfiguration - Class in org.apache.camel.model.cloud
 
DefaultServiceCallServiceLoadBalancerConfiguration() - Constructor for class org.apache.camel.model.cloud.DefaultServiceCallServiceLoadBalancerConfiguration
 
DefaultServiceCallServiceLoadBalancerConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.DefaultServiceCallServiceLoadBalancerConfiguration
 
DefaultServiceDefinition - Class in org.apache.camel.impl.cloud
 
DefaultServiceDefinition(String, String, int) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, String, int) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, int, ServiceHealth) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, String, int, ServiceHealth) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, int, Map<String, String>) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, String, int, Map<String, String>) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, int, Map<String, String>, ServiceHealth) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition(String, String, String, int, Map<String, String>, ServiceHealth) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
DefaultServiceDefinition.Builder - Class in org.apache.camel.impl.cloud
Fluent builder to construct ServiceDefinition.
DefaultServiceDiscovery - Class in org.apache.camel.impl.cloud
 
DefaultServiceDiscovery() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
DefaultServiceFilter - Class in org.apache.camel.impl.cloud
 
DefaultServiceFilter() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceFilter
 
DefaultServiceHealth - Class in org.apache.camel.impl.cloud
 
DefaultServiceHealth() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceHealth
 
DefaultServiceHealth(boolean) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceHealth
 
DefaultServiceHealth(Map<String, String>) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceHealth
 
DefaultServiceHealth(boolean, Map<String, String>) - Constructor for class org.apache.camel.impl.cloud.DefaultServiceHealth
 
DefaultServiceLoadBalancer - Class in org.apache.camel.impl.cloud
 
DefaultServiceLoadBalancer() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
DefaultServiceLoadBalancerFactory - Class in org.apache.camel.impl.cloud
 
DefaultServiceLoadBalancerFactory() - Constructor for class org.apache.camel.impl.cloud.DefaultServiceLoadBalancerFactory
 
DefaultShutdownStrategy - Class in org.apache.camel.impl
Default ShutdownStrategy which uses graceful shutdown.
DefaultShutdownStrategy() - Constructor for class org.apache.camel.impl.DefaultShutdownStrategy
 
DefaultShutdownStrategy(CamelContext) - Constructor for class org.apache.camel.impl.DefaultShutdownStrategy
 
DefaultStreamCachingStrategy - Class in org.apache.camel.impl
Default implementation of StreamCachingStrategy
DefaultStreamCachingStrategy() - Constructor for class org.apache.camel.impl.DefaultStreamCachingStrategy
 
DefaultSubUnitOfWork - Class in org.apache.camel.impl
A default implementation of SubUnitOfWork combined with a SubUnitOfWorkCallback to gather callbacks into this SubUnitOfWork state
DefaultSubUnitOfWork() - Constructor for class org.apache.camel.impl.DefaultSubUnitOfWork
 
DefaultTransformerRegistry - Class in org.apache.camel.impl
Default implementation of TransformerRegistry.
DefaultTransformerRegistry(CamelContext) - Constructor for class org.apache.camel.impl.DefaultTransformerRegistry
 
DefaultTransformerRegistry(CamelContext, List<TransformerDefinition>) - Constructor for class org.apache.camel.impl.DefaultTransformerRegistry
 
DefaultUnitOfWork - Class in org.apache.camel.impl
The default implementation of UnitOfWork
DefaultUnitOfWork(Exchange) - Constructor for class org.apache.camel.impl.DefaultUnitOfWork
 
DefaultUnitOfWork(Exchange, Logger) - Constructor for class org.apache.camel.impl.DefaultUnitOfWork
 
DefaultUnitOfWorkFactory - Class in org.apache.camel.impl
Default UnitOfWorkFactory
DefaultUnitOfWorkFactory() - Constructor for class org.apache.camel.impl.DefaultUnitOfWorkFactory
 
DefaultUuidGenerator - Class in org.apache.camel.impl
Default UuidGenerator optimized for Camel usage.
DefaultUuidGenerator(String) - Constructor for class org.apache.camel.impl.DefaultUuidGenerator
 
DefaultUuidGenerator() - Constructor for class org.apache.camel.impl.DefaultUuidGenerator
 
DefaultValidatorRegistry - Class in org.apache.camel.impl
Default implementation of ValidatorRegistry.
DefaultValidatorRegistry(CamelContext) - Constructor for class org.apache.camel.impl.DefaultValidatorRegistry
 
DefaultValidatorRegistry(CamelContext, List<ValidatorDefinition>) - Constructor for class org.apache.camel.impl.DefaultValidatorRegistry
 
defaultValue(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
The default value of the parameter.
defensiveCopyExchangeIfNeeded(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Performs a defensive copy of the exchange if needed
DeferProducer - Class in org.apache.camel.impl
A Producer that defers being started, until CamelContext has been started, this ensures that the producer is able to adapt to changes that may otherwise occur during starting CamelContext.
DeferProducer(Endpoint) - Constructor for class org.apache.camel.impl.DeferProducer
 
DeferServiceFactory - Class in org.apache.camel.processor
Factory to create services such as Producers and defer starting the created service, until CamelContext has been started.
DeferServiceStartupListener - Class in org.apache.camel.impl
A StartupListener that defers starting Services, until as late as possible during the startup process of CamelContext.
DeferServiceStartupListener() - Constructor for class org.apache.camel.impl.DeferServiceStartupListener
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.WireTapProcessor
 
deferStartService(Object, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
definition - Variable in class org.apache.camel.reifier.loadbalancer.LoadBalancerReifier
 
definition - Variable in class org.apache.camel.reifier.ProcessorReifier
 
definition - Variable in class org.apache.camel.reifier.transformer.TransformerReifier
 
definition - Variable in class org.apache.camel.reifier.validator.ValidatorReifier
 
delay(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
delay() - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
delay(long) - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
delay(long, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Delays the given time before continuing.
DelayDefinition - Class in org.apache.camel.model
Delays processing for a specified length of time
DelayDefinition() - Constructor for class org.apache.camel.model.DelayDefinition
 
DelayDefinition(Expression) - Constructor for class org.apache.camel.model.DelayDefinition
 
delayer(long) - Method in class org.apache.camel.model.RouteDefinition
Enable delayer for this route.
Delayer - Class in org.apache.camel.processor
A Delayer which delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.
Delayer(CamelContext, Processor, Expression, ScheduledExecutorService, boolean) - Constructor for class org.apache.camel.processor.Delayer
 
DelayerAdvice(long) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
delayPattern(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
delayPattern(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the delay pattern with delay intervals.
delayPattern(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the delay pattern with delay intervals.
delayPattern - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
delayPattern(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the delay pattern with delay intervals.
DelayProcessorSupport - Class in org.apache.camel.processor
A useful base class for any processor which provides some kind of throttling or delayed processing.
DelayProcessorSupport(CamelContext, Processor) - Constructor for class org.apache.camel.processor.DelayProcessorSupport
 
DelayProcessorSupport(CamelContext, Processor, ScheduledExecutorService, boolean) - Constructor for class org.apache.camel.processor.DelayProcessorSupport
 
delayTime(Long) - Method in class org.apache.camel.model.DelayDefinition
Sets the delay time in millis to delay
delete() - Method in class org.apache.camel.model.rest.RestDefinition
 
delete(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
delete() - Method in class org.apache.camel.model.rest.VerbDefinition
 
delete(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
DeleteVerbDefinition - Class in org.apache.camel.model.rest
Rest DELETE command
DeleteVerbDefinition() - Constructor for class org.apache.camel.model.rest.DeleteVerbDefinition
 
delimiter(String) - Method in class org.apache.camel.model.RecipientListDefinition
Delimiter used if the Expression returned multiple endpoints.
deliver() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Delivers all elements which are currently ready to deliver.
deliverNext() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Attempts to deliver a single element from the head of the resequencer queue (sequence).
deliverToFailureProcessor(Processor, boolean, Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
All redelivery attempts failed so move the exchange to the dead letter queue
deliverToOnRedeliveryProcessor() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
Gives an optional configured redelivery processor a chance to process before the Exchange will be redelivered.
deliveryAttemptInterval(long) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the interval in milli seconds the stream resequencer will at most wait while waiting for condition of being able to deliver.
description() - Method in class org.apache.camel.model.AggregateDefinition
 
description() - Method in class org.apache.camel.model.BeanDefinition
 
description(String, Endpoint) - Static method in class org.apache.camel.model.FromDefinition
 
description() - Method in class org.apache.camel.model.MarshalDefinition
 
description() - Method in class org.apache.camel.model.OnExceptionDefinition
 
description(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the description of this node
description(String, String, String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the description of this node
description() - Method in class org.apache.camel.model.PolicyDefinition
 
description(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
description(String, String, String) - Method in class org.apache.camel.model.rest.RestDefinition
 
description(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Description of the parameter.
description(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Description of the parameter.
description() - Method in class org.apache.camel.model.SagaDefinition
 
description() - Method in class org.apache.camel.model.SamplingDefinition
 
description() - Method in class org.apache.camel.model.ThrottleDefinition
 
description() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
description() - Method in class org.apache.camel.model.TransactedDefinition
 
description() - Method in class org.apache.camel.model.UnmarshalDefinition
 
description() - Method in class org.apache.camel.model.WhenDefinition
 
DescriptionDefinition - Class in org.apache.camel.model
To provide comments about the node.
DescriptionDefinition() - Constructor for class org.apache.camel.model.DescriptionDefinition
 
destination - Variable in class org.apache.camel.processor.SendProcessor
 
destinationExchangePattern - Variable in class org.apache.camel.processor.SendProcessor
 
destroy() - Method in class org.apache.camel.builder.NotifyBuilder
De-registers this builder from its CamelContext.
determineIfRedeliveryIsEnabled() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Determines if redelivery is enabled by checking if any of the redelivery policy settings may allow redeliveries.
determineRedeliveryDelay(Exchange, RedeliveryPolicy, long, int) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Determines the redelivery delay time by first inspecting the Message header Exchange.REDELIVERY_DELAY and if not present, defaulting to RedeliveryPolicy.calculateRedeliveryDelay(long, int)
disableBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
disableDebugger() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
disableHangupSupport() - Method in class org.apache.camel.main.MainSupport
Disable the hangup support.
disableJMX() - Method in class org.apache.camel.impl.AbstractCamelContext
 
disableRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
disableRedelivery() - Method in class org.apache.camel.processor.RedeliveryPolicy
Disables redelivery by setting maximum redeliveries to 0.
discardOnCompletionTimeout() - Method in class org.apache.camel.model.AggregateDefinition
Discards the aggregated message on completion timeout.
DistributionRatio - Class in org.apache.camel.processor.loadbalancer
 
DistributionRatio(int) - Constructor for class org.apache.camel.processor.loadbalancer.DistributionRatio
 
distributionRatioSum - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
dnsDomain(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the DNS domain to use for DNS/SNDSRV lookup.
DnsServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
DnsServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
 
DnsServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
 
dnsServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
dnsServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
dnsServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
dnsServiceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
dnsServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
dnsServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
dnsServiceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
dnsServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
doAddService(T) - Method in class org.apache.camel.impl.AbstractCamelContext
 
doAddService(T, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
doAddService(T, boolean, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
doAggregate(AtomicReference<Exchange>, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result.
doAggregateInternal(AggregationStrategy, AtomicReference<Exchange>, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result.
doAggregateSync(AggregationStrategy, AtomicReference<Exchange>, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result.
doAggregationComplete(String, List<Exchange>, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doAggregationRepositoryAdd(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doAssertIsSatisfied(long) - Method in class org.apache.camel.component.mock.MockEndpoint
 
doAsyncSendExchange(Endpoint, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.DefaultProducerCache
 
doBuildCamelEndpointUri(String, Integer, String, String) - Method in class org.apache.camel.impl.cloud.DefaultServiceCallExpression
 
doCatch(Class<? extends Throwable>) - Method in class org.apache.camel.model.TryDefinition
Handles the given exception
doCatch(Class<? extends Throwable>...) - Method in class org.apache.camel.model.TryDefinition
Handles the given exception(s)
doCreateChildProcessor(RouteContext, T, boolean) - Method in class org.apache.camel.impl.TypedProcessorFactory
 
doCreateProcessor(RouteContext, T) - Method in class org.apache.camel.impl.TypedProcessorFactory
 
doCreateTransformer(CamelContext) - Method in class org.apache.camel.reifier.transformer.TransformerReifier
 
doCreateValidator(CamelContext) - Method in class org.apache.camel.reifier.validator.ValidatorReifier
 
documentType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
Configures the document type to use.
doDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
doDone(Exchange, Exchange, Iterable<ProcessorExchangePair>, AsyncCallback, boolean, boolean) - Method in class org.apache.camel.processor.MulticastProcessor
Common work which must be done when we are done multicasting.
doDone(Exchange, boolean) - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
doEvaluate(Exchange, boolean) - Method in class org.apache.camel.builder.TokenPairExpressionIterator
Strategy to evaluate the exchange
doEvaluate(Exchange, boolean) - Method in class org.apache.camel.builder.TokenXMLExpressionIterator
Strategy to evaluate the exchange
doEvaluate(Exchange, boolean) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
Strategy to evaluate the exchange
doFinally() - Method in class org.apache.camel.model.TryDefinition
The finally block for a given handle
doGetDocument(Exchange, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
doGetProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doGetProducer(Endpoint) - Method in class org.apache.camel.impl.DefaultProducerCache
 
doInAsyncProducer(Endpoint, Exchange, AsyncCallback, ProducerCache.AsyncProducerCallback) - Method in class org.apache.camel.impl.DefaultProducerCache
Sends an exchange to an endpoint using a supplied callback supporting the asynchronous routing engine.
doInEvaluateAs(XPathExpression, Exchange, QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
doInit() - Method in class org.apache.camel.component.mock.MockEndpoint
 
doInit() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doInOptimisticLock(Exchange, String, AsyncCallback, int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doInvoke(Method, Exchange) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
doInvokeProxy(Object, Method, Object[]) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
doInvokeProxy(Object, Method, Object[]) - Method in class org.apache.camel.component.bean.CamelInvocationHandler
 
doInvokeProxy(Object, Method, Object[]) - Method in class org.apache.camel.component.bean.PojoMessageInvocationHandler
 
doLoadJarClassEntries(InputStream, String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
Loads all the class entries from the JAR.
domain(String) - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
The domain name;
done(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
done(boolean) - Method in class org.apache.camel.impl.EventNotifierCallback
 
done(Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
done() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
doneUoW(Exchange) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
doParseExpression() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
doParsePredicate() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
doProcess(String, LinkedList<String>) - Method in class org.apache.camel.main.MainSupport.Option
 
doProcess(String, LinkedList<String>) - Method in class org.apache.camel.main.MainSupport.ParameterOption
 
doProcess(String, String, LinkedList<String>) - Method in class org.apache.camel.main.MainSupport.ParameterOption
 
doProcess(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Exchange, String, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Processor, Exchange) - Static method in class org.apache.camel.processor.OnCompletionProcessor
Processes the exchange by the processors
doProcess(Exchange, AsyncCallback, Iterator<AsyncProcessor>, boolean) - Method in class org.apache.camel.processor.Pipeline
 
doResume() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doResume() - Method in class org.apache.camel.impl.RouteService
 
doRoutingSlip(Exchange, Object, AsyncCallback) - Method in class org.apache.camel.processor.RoutingSlip
 
doShutdown() - Method in class org.apache.camel.component.bean.BeanComponent
 
doShutdown() - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
doShutdown() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
doShutdown() - Method in class org.apache.camel.impl.DefaultRoute
 
doShutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit, boolean, boolean, boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
doShutdown() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
doShutdown() - Method in class org.apache.camel.impl.RouteService
 
doShutdown() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
doShutdown() - Method in class org.apache.camel.impl.SupervisingRouteController
 
doShutdown() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doShutdown() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doShutdown() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doShutdown() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
doShutdown() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doShutdown() - Method in class org.apache.camel.processor.MulticastProcessor
 
doShutdown() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doShutdown() - Method in class org.apache.camel.processor.PollEnricher
 
doShutdown() - Method in class org.apache.camel.processor.RecipientList
 
doShutdown() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doShutdown() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
doShutdown() - Method in class org.apache.camel.processor.RoutingSlip
 
doShutdown() - Method in class org.apache.camel.processor.SendProcessor
 
doShutdown() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doShutdown() - Method in class org.apache.camel.processor.Throttler
 
doShutdown() - Method in class org.apache.camel.processor.WireTapProcessor
 
doShutdownRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
doStart() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
doStart() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
doStart() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
doStart() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
doStart() - Method in class org.apache.camel.component.bean.BeanProcessor
 
doStart() - Method in class org.apache.camel.component.bean.BeanProducer
 
doStart() - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
doStart() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
doStart() - Method in class org.apache.camel.component.test.TestEndpoint
 
doStart() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doStart() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
doStart() - Method in class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
doStart() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
doStart() - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
doStart() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
doStart() - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
doStart() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
doStart() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
doStart() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
doStart() - Method in class org.apache.camel.impl.DefaultDebugger
 
doStart() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
doStart() - Method in class org.apache.camel.impl.DefaultInflightRepository
 
doStart() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
doStart() - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
doStart() - Method in class org.apache.camel.impl.DefaultProducerCache
 
doStart() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
doStart() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
doStart() - Method in class org.apache.camel.impl.DefaultRoute
 
doStart() - Method in class org.apache.camel.impl.DefaultRouteController
 
doStart() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
doStart() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
doStart() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
doStart() - Method in class org.apache.camel.impl.DeferProducer
 
doStart() - Method in class org.apache.camel.impl.FileStateRepository
 
doStart() - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
doStart() - Method in class org.apache.camel.impl.GzipDataFormat
 
doStart() - Method in class org.apache.camel.impl.MemoryStateRepository
 
doStart() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
doStart() - Method in class org.apache.camel.impl.RouteService
 
doStart() - Method in class org.apache.camel.impl.SerializationDataFormat
 
doStart() - Method in class org.apache.camel.impl.ServicePool
 
doStart() - Method in class org.apache.camel.impl.StringDataFormat
 
doStart() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
doStart() - Method in class org.apache.camel.impl.SupervisingRouteController
 
doStart() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
doStart() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
doStart() - Method in class org.apache.camel.impl.ZipDataFormat
 
doStart() - Method in class org.apache.camel.main.Main
 
doStart() - Method in class org.apache.camel.main.MainDurationEventNotifier
 
doStart() - Method in class org.apache.camel.main.MainSupport
 
doStart() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doStart() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
doStart() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
doStart() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doStart() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStart() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
doStart() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
doStart() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doStart() - Method in class org.apache.camel.processor.Enricher
 
doStart() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doStart() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
doStart() - Method in class org.apache.camel.processor.FilterProcessor
 
doStart() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStart() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
doStart() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
doStart() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
doStart() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
doStart() - Method in class org.apache.camel.processor.LogProcessor
 
doStart() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStart() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doStart() - Method in class org.apache.camel.processor.Pipeline
 
doStart() - Method in class org.apache.camel.processor.PollEnricher
 
doStart() - Method in class org.apache.camel.processor.RecipientList
 
doStart() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doStart() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
doStart() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
doStart() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
doStart() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
doStart() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
doStart() - Method in class org.apache.camel.processor.Resequencer
 
doStart() - Method in class org.apache.camel.processor.RollbackProcessor
 
doStart() - Method in class org.apache.camel.processor.RoutingSlip
 
doStart() - Method in class org.apache.camel.processor.ScriptProcessor
 
doStart() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
doStart() - Method in class org.apache.camel.processor.SendProcessor
 
doStart() - Method in class org.apache.camel.processor.SetBodyProcessor
 
doStart() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
doStart() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
doStart() - Method in class org.apache.camel.processor.SortProcessor
 
doStart() - Method in class org.apache.camel.processor.StopProcessor
 
doStart() - Method in class org.apache.camel.processor.StreamResequencer
 
doStart() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStart() - Method in class org.apache.camel.processor.Throttler
 
doStart() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
doStart() - Method in class org.apache.camel.processor.TransformProcessor
 
doStart() - Method in class org.apache.camel.processor.TryProcessor
 
doStart() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStart() - Method in class org.apache.camel.processor.WrapProcessor
 
doStartCamel() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doStartManagementStrategy() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
doStartOrResumeRoutes(Map<String, RouteService>, boolean, boolean, boolean, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
Starts or resumes the routes
doStop() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
doStop() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
doStop() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
doStop() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
doStop() - Method in class org.apache.camel.component.bean.BeanProcessor
 
doStop() - Method in class org.apache.camel.component.bean.BeanProducer
 
doStop() - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
doStop() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doStop() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
doStop() - Method in class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
doStop() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
doStop() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
doStop() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
doStop() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
doStop() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
doStop() - Method in class org.apache.camel.impl.DefaultDebugger
 
doStop() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
doStop() - Method in class org.apache.camel.impl.DefaultInflightRepository
 
doStop() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
doStop() - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
doStop() - Method in class org.apache.camel.impl.DefaultProducerCache
 
doStop() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
doStop() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
doStop() - Method in class org.apache.camel.impl.DefaultRoute
 
doStop() - Method in class org.apache.camel.impl.DefaultRouteController
 
doStop() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
doStop() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
doStop() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
doStop() - Method in class org.apache.camel.impl.DeferProducer
 
doStop() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
doStop() - Method in class org.apache.camel.impl.FileStateRepository
 
doStop() - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
doStop() - Method in class org.apache.camel.impl.GzipDataFormat
 
doStop() - Method in class org.apache.camel.impl.MemoryStateRepository
 
doStop() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
doStop() - Method in class org.apache.camel.impl.RouteService
 
doStop() - Method in class org.apache.camel.impl.SerializationDataFormat
 
doStop() - Method in class org.apache.camel.impl.ServicePool
 
doStop() - Method in class org.apache.camel.impl.StringDataFormat
 
doStop() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
doStop() - Method in class org.apache.camel.impl.SupervisingRouteController
 
doStop() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
doStop() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
doStop() - Method in class org.apache.camel.impl.ZipDataFormat
 
doStop() - Method in class org.apache.camel.main.Main
 
doStop() - Method in class org.apache.camel.main.MainSupport
 
doStop() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doStop() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
doStop() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
doStop() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doStop() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStop() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
doStop() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
doStop() - Method in class org.apache.camel.processor.Enricher
 
doStop() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doStop() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
doStop() - Method in class org.apache.camel.processor.FilterProcessor
 
doStop() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStop() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
doStop() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
doStop() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
doStop() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStop() - Method in class org.apache.camel.processor.LogProcessor
 
doStop() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStop() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doStop() - Method in class org.apache.camel.processor.Pipeline
 
doStop() - Method in class org.apache.camel.processor.PollEnricher
 
doStop() - Method in class org.apache.camel.processor.RecipientList
 
doStop() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doStop() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
doStop() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
doStop() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
doStop() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
doStop() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
doStop() - Method in class org.apache.camel.processor.Resequencer
 
doStop() - Method in class org.apache.camel.processor.RollbackProcessor
 
doStop() - Method in class org.apache.camel.processor.RoutingSlip
 
doStop() - Method in class org.apache.camel.processor.ScriptProcessor
 
doStop() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
doStop() - Method in class org.apache.camel.processor.SendProcessor
 
doStop() - Method in class org.apache.camel.processor.SetBodyProcessor
 
doStop() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
doStop() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
doStop() - Method in class org.apache.camel.processor.SortProcessor
 
doStop() - Method in class org.apache.camel.processor.StopProcessor
 
doStop() - Method in class org.apache.camel.processor.StreamResequencer
 
doStop() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStop() - Method in class org.apache.camel.processor.Throttler
 
doStop() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
doStop() - Method in class org.apache.camel.processor.TransformProcessor
 
doStop() - Method in class org.apache.camel.processor.TryProcessor
 
doStop() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStop() - Method in class org.apache.camel.processor.WrapProcessor
 
doSuspend() - Method in class org.apache.camel.impl.AbstractCamelContext
 
doSuspend() - Method in class org.apache.camel.impl.RouteService
 
doTry() - Method in class org.apache.camel.model.ProcessorDefinition
Creates a try/catch block
doubleQuotedLiteralText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
doubleQuotedLiteralWithFunctionsText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
DoubleQuoteEnd - Class in org.apache.camel.language.simple.ast
Ends a block enclosed by double quotes
DoubleQuoteEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.DoubleQuoteEnd
 
DoubleQuoteStart - Class in org.apache.camel.language.simple.ast
Starts a block enclosed by double quotes
DoubleQuoteStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
doWarmUp() - Method in class org.apache.camel.impl.RouteService
 
dumpAllTracedMessages() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpAllTracedMessagesAsXml() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpModelAsXml(CamelContext, NamedNode) - Static method in class org.apache.camel.model.ModelHelper
Dumps the definition as XML
dumpTracedMessages(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpTracedMessagesAsXml(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
dumpTracedMessagesAsXml(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
duration - Variable in class org.apache.camel.main.MainSupport
 
durationHitExitCode - Variable in class org.apache.camel.main.MainSupport
 
durationIdle - Variable in class org.apache.camel.main.MainSupport
 
durationMaxMessages - Variable in class org.apache.camel.main.MainSupport
 
DurationRoutePolicy - Class in org.apache.camel.impl
RoutePolicy which executes for a duration and then triggers an action.
DurationRoutePolicy() - Constructor for class org.apache.camel.impl.DurationRoutePolicy
 
DurationRoutePolicy(CamelContext, String) - Constructor for class org.apache.camel.impl.DurationRoutePolicy
 
DurationRoutePolicyFactory - Class in org.apache.camel.impl
RoutePolicyFactory which executes for a duration and then triggers an action.
DurationRoutePolicyFactory() - Constructor for class org.apache.camel.impl.DurationRoutePolicyFactory
 
dynamicAware - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
dynamicMap - Variable in class org.apache.camel.impl.AbstractDynamicRegistry
 
dynamicRouter(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Dynamic Router EIP: Creates a dynamic router allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
dynamicRouter() - Method in class org.apache.camel.model.ProcessorDefinition
Dynamic Router EIP: Creates a dynamic router allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
DynamicRouter - Class in org.apache.camel.processor
Implements a Dynamic Router pattern where the destination(s) is computed at runtime.
DynamicRouter(CamelContext) - Constructor for class org.apache.camel.processor.DynamicRouter
 
DynamicRouter(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.DynamicRouter
 
DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Routes messages based on dynamic rules
DynamicRouterDefinition() - Constructor for class org.apache.camel.model.DynamicRouterDefinition
 
DynamicRouterDefinition(Expression) - Constructor for class org.apache.camel.model.DynamicRouterDefinition
 
dynamicSize() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
dynamicUri(boolean) - Method in class org.apache.camel.model.WireTapDefinition
Whether the uri is dynamic or static.

E

eager(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets whether to eagerly add the key to the idempotent repository or wait until the exchange is complete.
eagerCheckCompletion() - Method in class org.apache.camel.model.AggregateDefinition
Use eager completion checking which means that the completionPredicate will use the incoming Exchange.
emptyValue - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
enableBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
enableCORS(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify whether to enable CORS which means Camel will automatic include CORS in the HTTP headers in the response.
enableCORS(boolean) - Method in class org.apache.camel.model.rest.RestDefinition
 
enableDebugger() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
enableHangupSupport() - Method in class org.apache.camel.main.MainSupport
Hangup support is enabled by default.
enableSaxon() - Method in class org.apache.camel.builder.xml.XPathBuilder
Enables Saxon on this particular XPath expression, as XPathBuilder.saxon() sets the default static XPathFactory which may have already been initialised by previous XPath expressions
enableTrace() - Method in class org.apache.camel.main.MainSupport
 
end() - Method in class org.apache.camel.model.ChoiceDefinition
 
end() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
end() - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
end() - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
end() - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
end() - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
end() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
end() - Method in class org.apache.camel.model.HystrixConfigurationDefinition
End of configuration.
end() - Method in class org.apache.camel.model.HystrixDefinition
 
end() - Method in class org.apache.camel.model.OnCompletionDefinition
 
end() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block
end() - Method in class org.apache.camel.model.RecipientListDefinition
 
end() - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
end() - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
end() - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
end() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
end() - Method in class org.apache.camel.model.WireTapDefinition
 
endChoice() - Method in class org.apache.camel.model.ChoiceDefinition
 
endChoice() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block and returns back to the choice() DSL.
endDoTry() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block and returns back to the doTry() DSL.
endHeader() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Ends the configuration of this header
endHystrix() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block and returns back to the hystrix() DSL.
endParam() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Ends the configuration of this parameter
endParent() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
endParent() - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
endParent() - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
endParent() - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
endParent() - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
endParent() - Method in class org.apache.camel.model.ProcessorDefinition
Strategy to allow ProcessorDefinitions to have special logic when using end() in the DSL to return back to the intended parent.
endParent() - Method in class org.apache.camel.model.WhenDefinition
 
endpoint(String) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the given URI to an endpoint
endpoint(String, Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the given URI to an endpoint of the specified type
endpoint(String) - Method in class org.apache.camel.builder.ProxyBuilder
Send the proxied message to this endpoint
endpoint(Endpoint) - Method in class org.apache.camel.builder.ProxyBuilder
Send the proxied message to this endpoint
endpoint - Variable in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
endpoint - Variable in class org.apache.camel.model.SendDefinition
 
EndpointKey - Class in org.apache.camel.impl
Key used in DefaultEndpointRegistry in DefaultCamelContext, to ensure a consistent lookup.
EndpointKey(String) - Constructor for class org.apache.camel.impl.EndpointKey
 
EndpointKey(String, boolean) - Constructor for class org.apache.camel.impl.EndpointKey
Optimized when the uri is already normalized.
endpointProperty(String, String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
For additional configuration options on endpoint level

The value can use # to refer to a bean to lookup in the registry.

EndpointRequiredDefinition - Interface in org.apache.camel.model
A ProcessorDefinition that requires to be configured with an Endpoint such as SendDefinition.
endpoints(String...) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the list of URIs into a list of Endpoint instances
endpoints(Endpoint...) - Method in class org.apache.camel.builder.BuilderSupport
Helper method to create a list of Endpoint instances
EndpointTransformerDefinition - Class in org.apache.camel.model.transformer
Represents an endpoint Transformer which leverages camel Endpoint to perform transformation.
EndpointTransformerDefinition() - Constructor for class org.apache.camel.model.transformer.EndpointTransformerDefinition
 
EndpointValidatorDefinition - Class in org.apache.camel.model.validator
Represents an endpoint Validator which leverages camel validator component such as Validator Component and Bean Validator Component to perform content validation.
EndpointValidatorDefinition() - Constructor for class org.apache.camel.model.validator.EndpointValidatorDefinition
 
endResponseHeader() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Ends the configuration of this response message
endResponseMessage() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
Ends the configuration of this response message
endRest() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block and returns back to the rest() DSL.
endSecurityDefinition() - Method in class org.apache.camel.model.rest.RestSecurityDefinition
Ends the configuration of this security
endSubUnitOfWork(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
endsWith(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
endsWith(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
endToken - Variable in class org.apache.camel.builder.TokenPairExpressionIterator
 
endTransactedBy(Object) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
endTransactedBy(Object) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
enrich(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
enrich(String, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
enrich(String, AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
enrich(String, AggregationStrategy, boolean, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
enrich() - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
EnrichClause<T extends ProcessorDefinition<?>> - Class in org.apache.camel.builder
 
EnrichClause(T) - Constructor for class org.apache.camel.builder.EnrichClause
 
EnrichDefinition - Class in org.apache.camel.model
Enriches a message with data from a secondary resource
EnrichDefinition() - Constructor for class org.apache.camel.model.EnrichDefinition
 
EnrichDefinition(AggregationStrategy) - Constructor for class org.apache.camel.model.EnrichDefinition
 
Enricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
Enricher(Expression) - Constructor for class org.apache.camel.processor.Enricher
 
enrichWith(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder.
enrichWith(String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder.
enrichWith(String, boolean, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder.
entrySet() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
ENVIRONMENT_VARIABLES - Static variable in class org.apache.camel.builder.xml.Namespaces
 
equals(Object) - Method in class org.apache.camel.component.bean.BeanInfoCacheKey
 
equals(Object) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
equals(Object) - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
errorHandler(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.RouteBuilder
Installs the given error handler builder
errorHandler(ErrorHandlerFactory) - Method in class org.apache.camel.model.RouteDefinition
Installs the given error handler builder.
ErrorHandler - Interface in org.apache.camel.processor
An interface used to represent an error handler
errorHandler - Variable in class org.apache.camel.processor.RoutingSlip
 
ErrorHandlerBuilder - Interface in org.apache.camel.builder
A builder of a Error Handler
ErrorHandlerBuilderRef - Class in org.apache.camel.builder
Represents a proxy to an error handler builder which is resolved by named reference
ErrorHandlerBuilderRef(String) - Constructor for class org.apache.camel.builder.ErrorHandlerBuilderRef
 
ErrorHandlerBuilderSupport - Class in org.apache.camel.builder
Base class for builders of error handling.
ErrorHandlerBuilderSupport() - Constructor for class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
ErrorHandlerReifier - Class in org.apache.camel.reifier
 
ErrorHandlerSupport - Class in org.apache.camel.processor
Support class for ErrorHandler implementations.
ErrorHandlerSupport() - Constructor for class org.apache.camel.processor.ErrorHandlerSupport
 
EtcdServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
EtcdServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
EtcdServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
etcdServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
etcdServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
etcdServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
etcdServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
etcdServiceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
etcdServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.builder.SimpleBuilder
 
evaluate(Exchange) - Method in class org.apache.camel.builder.TokenPairExpressionIterator
 
evaluate(Exchange) - Method in class org.apache.camel.builder.TokenXMLExpressionIterator
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.builder.ValueBuilder
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
evaluate(CamelContext, Object, Class<T>) - Method in class org.apache.camel.builder.xml.XPathBuilder
Evaluates the given xpath using the provided body.
evaluate(CamelContext, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Evaluates the given xpath using the provided body as a String return type.
evaluate(Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
evaluate(Exchange) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
evaluate(Exchange) - Method in class org.apache.camel.language.bean.BeanExpression
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.language.bean.BeanExpression
 
evaluate(Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
evaluateAs(Exchange, QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
Evaluates the expression as the given result type
EvaluateExpressionProcessor - Class in org.apache.camel.processor
A Processor which evaluates an Expression and stores the result as a property on the Exchange with the key Exchange.EVALUATE_EXPRESSION_RESULT.
EvaluateExpressionProcessor(Expression) - Constructor for class org.apache.camel.processor.EvaluateExpressionProcessor
 
EventDrivenConsumerRoute - Class in org.apache.camel.impl
A DefaultRoute which starts with an Event Driven Consumer

Use the API from CamelContext to control the lifecycle of a route, such as starting and stopping using the RouteController.startRoute(String) and RouteController.stopRoute(String) methods.

EventDrivenConsumerRoute(RouteContext, Endpoint, Processor) - Constructor for class org.apache.camel.impl.EventDrivenConsumerRoute
 
EventNotifierCallback - Class in org.apache.camel.impl
Helper class to notify on exchange sending events in async engine
EventNotifierCallback(AsyncCallback, Exchange, Endpoint) - Constructor for class org.apache.camel.impl.EventNotifierCallback
 
EventNotifierProducer - Class in org.apache.camel.processor
Ensures a Producer do send EventNotifier notifications when sending.
EventNotifierProducer(Producer) - Constructor for class org.apache.camel.processor.EventNotifierProducer
The producer which should be executed and emit EventNotifier notifications.
example(String, String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Adds a body example with the given content-type
example(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Adds a single example
example(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets an example of this header.
example(String, String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
Adds an example
exception(Class<? extends Throwable>...) - Method in class org.apache.camel.model.CatchDefinition
The exception(s) to catch.
exceptionClasses(List<Class<? extends Throwable>>) - Method in class org.apache.camel.model.CatchDefinition
The exceptions to catch.
exceptionClasses(Class<? extends Throwable>) - Method in class org.apache.camel.model.CatchDefinition
Sets the exception class that the CatchType want to catch
ExceptionFailureStatistics - Class in org.apache.camel.processor.loadbalancer
Statistics about exception failures for load balancers that reacts on exceptions
ExceptionFailureStatistics() - Constructor for class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
exceptionMessage() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the exception message on an exchange
exceptionMessage() - Method in class org.apache.camel.builder.BuilderSupport
Returns a exception expression value builder
exceptionPolicies - Variable in class org.apache.camel.processor.ErrorHandlerSupport
 
exceptionPolicy - Variable in class org.apache.camel.processor.ErrorHandlerSupport
 
ExceptionPolicyKey - Class in org.apache.camel.processor.exceptionpolicy
Exception policy key is a compound key for storing: route id + exception class + when => exception type.
ExceptionPolicyKey(String, Class<? extends Throwable>, WhenDefinition) - Constructor for class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
Key for exception clause
exceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
Sets the exception policy to use
ExceptionPolicyStrategy - Interface in org.apache.camel.processor.exceptionpolicy
A strategy to determine which OnExceptionDefinition should handle the thrown exception.
exceptionStackTrace() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the exception stacktrace on an exchange
exchange(BiFunction<Exchange, Exchange, Exchange>) - Method in class org.apache.camel.builder.AggregationStrategyClause
Define an aggregation strategy which targets the exchnage.
exchange() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the exchange
exchange(Function<Exchange, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of the exchange
exchange() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the exchange
exchange(Predicate<Exchange>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the Exchange.
exchange(Consumer<Exchange>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the Exchange.
EXCHANGE_PROPERTY - Static variable in class org.apache.camel.builder.xml.Namespaces
 
ExchangeBuilder - Class in org.apache.camel.builder
Builder to create Exchange and add headers and set body on the Exchange Message.
ExchangeBuilder(CamelContext) - Constructor for class org.apache.camel.builder.ExchangeBuilder
 
exchangeExceptionExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception set on the exchange
exchangeExceptionExpression(Class<Exception>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception set on the exchange

Is used to get the caused exception that typically have been wrapped in some sort of Camel wrapper exception

exchangeExceptionMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception message set on the exchange
exchangeExceptionOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges exception invoking methods defined in a simple OGNL notation
exchangeExceptionStackTraceExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception stacktrace set on the exchange
exchangeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchange
exchangeExpression(Function<Exchange, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the exchange
exchangeFormatter - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
exchangeFormatterRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
exchangeFormatterRef(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
exchangeFormatterRef - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
exchangeFormatterRef(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
exchangeIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an Expression for the exchange id
exchangeOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchange invoking methods defined in a simple OGNL notation
exchangePattern() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the exchange pattern
exchangePatternExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the exchange pattern
ExchangePatternProcessor - Class in org.apache.camel.processor
Processor to set ExchangePattern on the Exchange.
ExchangePatternProcessor() - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
ExchangePatternProcessor(ExchangePattern) - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
exchangeProperties() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the exchange properties
exchangeProperties() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the exchange properties
exchangePropertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the exchange properties of exchange
exchangeProperty(String) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for properties on an exchange
exchangeProperty(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given exchange property
exchangeProperty(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an exchange property of the given name
exchangeProperty(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an exchange property of the given name
exchangeProperty(String) - Static method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
exchangePropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value of exchange with the given name
ExchangePropertyExpression - Class in org.apache.camel.model.language
To use a Camel Exchange property in expressions or predicates.
ExchangePropertyExpression() - Constructor for class org.apache.camel.model.language.ExchangePropertyExpression
 
ExchangePropertyExpression(String) - Constructor for class org.apache.camel.model.language.ExchangePropertyExpression
 
ExchangePropertyLanguage - Class in org.apache.camel.language.property
A language for exchange property expressions.
ExchangePropertyLanguage() - Constructor for class org.apache.camel.language.property.ExchangePropertyLanguage
 
executionIsolationSemaphoreMaxConcurrentRequests(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Number of concurrent requests permitted to HystrixCommand.run().
executionIsolationStrategy(String) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
What isolation strategy HystrixCommand.run() will be executed with.
executionIsolationThreadInterruptOnTimeout(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether the execution thread should attempt an interrupt (using Future cancel) when a thread times out.
executionTimeoutEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether the timeout mechanism is enabled for this command
executionTimeoutInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Time in milliseconds at which point the command will timeout and halt execution.
executorService - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
executorService(ExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
If using parallelProcessing you can specify a custom thread pool to be used.
executorService(ExecutorService) - Method in class org.apache.camel.model.DelayDefinition
To use a custom Thread Pool if asyncDelay has been enabled.
executorService(ExecutorService) - Method in interface org.apache.camel.model.ExecutorServiceAwareDefinition
Setting the executor service for executing
executorService(ExecutorService) - Method in class org.apache.camel.model.MulticastDefinition
To use a custom Thread Pool to be used for parallel processing.
executorService(ExecutorService) - Method in class org.apache.camel.model.OnCompletionDefinition
To use a custom Thread Pool to be used for parallel processing.
executorService(ExecutorService) - Method in class org.apache.camel.model.RecipientListDefinition
To use a custom Thread Pool to be used for parallel processing.
executorService(ExecutorService) - Method in class org.apache.camel.model.SplitDefinition
To use a custom Thread Pool to be used for parallel processing.
executorService(ExecutorService) - Method in class org.apache.camel.model.ThreadsDefinition
To use a custom thread pool
executorService(ExecutorService) - Method in class org.apache.camel.model.ThrottleDefinition
To use a custom thread pool (ScheduledExecutorService) by the throttler.
executorService(ExecutorService) - Method in class org.apache.camel.model.WireTapDefinition
Uses a custom thread pool
executorService - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
ExecutorServiceAwareDefinition<Type extends ProcessorDefinition<?>> - Interface in org.apache.camel.model
Enables definitions to support concurrency using ExecutorService
executorServiceRef - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
executorServiceRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets a reference to a thread pool to be used for redelivery.
executorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
If using parallelProcessing you can specify a custom thread pool to be used.
executorServiceRef(String) - Method in class org.apache.camel.model.DelayDefinition
Refers to a custom Thread Pool if asyncDelay has been enabled.
executorServiceRef(String) - Method in interface org.apache.camel.model.ExecutorServiceAwareDefinition
Setting the executor service for executing
executorServiceRef(String) - Method in class org.apache.camel.model.MulticastDefinition
Refers to a custom Thread Pool to be used for parallel processing.
executorServiceRef(String) - Method in class org.apache.camel.model.OnCompletionDefinition
Refers to a custom Thread Pool to be used for parallel processing.
executorServiceRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
Refers to a custom Thread Pool to be used for parallel processing.
executorServiceRef(String) - Method in class org.apache.camel.model.SplitDefinition
Refers to a custom Thread Pool to be used for parallel processing.
executorServiceRef(String) - Method in class org.apache.camel.model.ThreadsDefinition
To refer to a custom thread pool or use a thread pool profile (as overlay)
executorServiceRef(String) - Method in class org.apache.camel.model.ThrottleDefinition
To use a custom thread pool (ScheduledExecutorService) by the throttler.
executorServiceRef(String) - Method in class org.apache.camel.model.WireTapDefinition
Uses a custom thread pool
exitCode - Variable in class org.apache.camel.main.MainSupport
 
expect(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Expect a given token
expectAndAcceptMore(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Expect and accept a given number of tokens in sequence.
expectedBodiesReceived(List<?>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in the specified order

Important: The number of values must match the expected number of messages, so if you expect 3 messages, then there must be 3 values.

expectedBodiesReceived(Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets an expectation that the given body values are received by this endpoint

Important: The number of bodies must match the expected number of messages, so if you expect 3 messages, then there must be 3 bodies.

expectedBodiesReceivedInAnyOrder(List<?>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in any order

Important: The number of bodies must match the expected number of messages, so if you expect 3 messages, then there must be 3 bodies.

expectedBodiesReceivedInAnyOrder(Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in any order

Important: The number of bodies must match the expected number of messages, so if you expect 3 messages, then there must be 3 bodies.

expectedBodyReceived() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body value are received by this endpoint
expectedExchangePattern(ExchangePattern) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have the given exchange pattern
expectedFileExists(String) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that a file exists with the given name
expectedFileExists(String, String) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that a file exists with the given name

Will wait at most 5 seconds while checking for the existence of the file.

expectedHeaderReceived(String, Object) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets an expectation that the given header name & value are received by this endpoint

You can set multiple expectations for different header names.

expectedHeaderValuesReceivedInAnyOrder(String, List<?>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given header values are received by this endpoint in any order.
expectedHeaderValuesReceivedInAnyOrder(String, Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given header values are received by this endpoint in any order

Important: The number of values must match the expected number of messages, so if you expect 3 messages, then there must be 3 values.

expectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the expected number of message exchanges that should be received by this endpoint If you want to assert that exactly n messages arrives to this mock endpoint, then see also the MockEndpoint.setAssertPeriod(long) method for further details.
expectedMessagesMatches(Predicate...) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets an expectation that the given predicates matches the received messages by this endpoint
expectedMinimumMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the minimum number of expected message exchanges that should be received by this endpoint
expectedPropertyReceived(String, Object) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets an expectation that the given property name & value are received by this endpoint

You can set multiple expectations for different property names.

expectedPropertyValuesReceivedInAnyOrder(String, List<?>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given property values are received by this endpoint in any order.
expectedPropertyValuesReceivedInAnyOrder(String, Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given property values are received by this endpoint in any order

Important: The number of values must match the expected number of messages, so if you expect 3 messages, then there must be 3 values.

expects(Runnable) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds the expectation which will be invoked when enough messages are received
expectsAscending(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have ascending values of the given expression such as a user generated counter value
expectsAscending() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have ascending values of the given expression such as a user generated counter value
expectsDescending(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have descending values of the given expression such as a user generated counter value
expectsDescending() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have descending values of the given expression such as a user generated counter value
expectsMessageCount(int, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
expectsNoDuplicates(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that no duplicate messages should be received using the expression to determine the message ID
expectsNoDuplicates() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that no duplicate messages should be received using the expression to determine the message ID
explainComponentJson(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
explainDataFormatJson(String, DataFormat, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
explainEipJson(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
explainEndpointJson(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
ExplicitCamelContextNameStrategy - Class in org.apache.camel.impl
Strategy to used an explicit (fixed) name for CamelContext.
ExplicitCamelContextNameStrategy(String) - Constructor for class org.apache.camel.impl.ExplicitCamelContextNameStrategy
 
exponentialBackOff() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
Enable exponential backoff
exponentialBackOff(boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
exponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
expression(Expression) - Method in class org.apache.camel.builder.ExpressionClause
Specify an Expression instance
expression(Expression) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Specify an Expression instance
expression(ExpressionDefinition) - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
expression(Expression) - Method in class org.apache.camel.component.mock.AssertionClause
 
expression(ExpressionDefinition) - Method in class org.apache.camel.component.mock.AssertionClause
 
expression - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
expression(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression.
expression(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom Expression to use.
expression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom Expression to use.
expression() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom Expression to use through an expression builder clause.
expression(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom Expression to use.
expression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom Expression to use.
expression() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom Expression to use through an expression builder clause.
expression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
expression - Variable in class org.apache.camel.processor.RoutingSlip
 
expression - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ExpressionBuilder - Class in org.apache.camel.builder
A helper class for working with expressions.
ExpressionClause<T> - Class in org.apache.camel.builder
Represents an expression clause within the DSL which when the expression is complete the clause continues to another part of the DSL
ExpressionClause(T) - Constructor for class org.apache.camel.builder.ExpressionClause
 
ExpressionClauseSupport<T> - Class in org.apache.camel.builder
A support class for building expression clauses.
ExpressionClauseSupport(T) - Constructor for class org.apache.camel.builder.ExpressionClauseSupport
 
expressionConfiguration(ServiceCallExpressionConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the Expression using the given configuration.
expressionConfiguration(ServiceCallExpressionConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the Expression using the given configuration.
ExpressionDefinition - Class in org.apache.camel.model.language
A useful base class for an expression
ExpressionDefinition() - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(String) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(Predicate) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(Expression) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionNode - Class in org.apache.camel.model
A base class for nodes which contain an expression and a number of outputs
ExpressionNode() - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(ExpressionDefinition) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(Expression) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(Predicate) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNodeHelper - Class in org.apache.camel.model
Helper for ExpressionNode
ExpressionResultComparator - Interface in org.apache.camel.processor.resequencer
A SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.
ExpressionSubElementDefinition - Class in org.apache.camel.model
Represents an expression sub element
ExpressionSubElementDefinition() - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
ExpressionSubElementDefinition(Expression) - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
ExpressionSubElementDefinition(Predicate) - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
expressionType(ExpressionDefinition) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
extractFutureBody(Future<?>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractFutureBody(Future<?>, long, TimeUnit, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractResultBody(Exchange) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
Extracts the body from the given result.
extractResultBody(Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractResultBody(Exchange, ExchangePattern) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 

F

factory(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
Configures to use the provided XPath factory.
factoryClassName(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the factory class name to use
fail(Object) - Method in class org.apache.camel.component.mock.MockEndpoint
 
failover() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer

Will not round robin and inherit the error handler.

failover(Class<?>...) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer

Will not round robin and inherit the error handler.

failover(int, boolean, boolean, Class<?>...) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer
failover(int, boolean, boolean, boolean, Class<?>...) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer
FailOverLoadBalancer - Class in org.apache.camel.processor.loadbalancer
This FailOverLoadBalancer will failover to use next processor when an exception occurred

This implementation mirrors the logic from the Pipeline in the async variation as the failover load balancer is a specialized pipeline.

FailOverLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailOverLoadBalancer(List<Class<?>>) - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailOverLoadBalancer.State - Class in org.apache.camel.processor.loadbalancer
 
FailoverLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Failover load balancer The failover load balancer is capable of trying the next processor in case an Exchange failed with an exception during processing.
FailoverLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
failureProcessor - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
fallbackEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether HystrixCommand.getFallback() should be attempted when failure occurs.
fallbackIsolationSemaphoreMaxConcurrentRequests(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Number of concurrent requests permitted to HystrixCommand.getFallback().
FatalFallbackErrorHandler - Class in org.apache.camel.processor
An ErrorHandler used as a safe fallback when processing by other error handlers such as the OnExceptionDefinition.
FatalFallbackErrorHandler(Processor) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
FatalFallbackErrorHandler(Processor, boolean) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
faultBodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the fault messages body
faultBodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges fault message body converted to the given type
FhirDataformat - Class in org.apache.camel.model.dataformat
 
FhirDataformat(String) - Constructor for class org.apache.camel.model.dataformat.FhirDataformat
 
FhirDataformat() - Constructor for class org.apache.camel.model.dataformat.FhirDataformat
 
fhirJson() - Method in class org.apache.camel.builder.DataFormatClause
Uses the FHIR JSON data format
fhirJson(String) - Method in class org.apache.camel.builder.DataFormatClause
 
fhirJson(boolean) - Method in class org.apache.camel.builder.DataFormatClause
 
fhirJson(String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
 
FhirJsonDataFormat - Class in org.apache.camel.model.dataformat
The FHIR JSon data format is used to marshall/unmarshall to/from FHIR objects to/from JSON.
FhirJsonDataFormat() - Constructor for class org.apache.camel.model.dataformat.FhirJsonDataFormat
 
fhirXml() - Method in class org.apache.camel.builder.DataFormatClause
Uses the FHIR XML data format
fhirXml(String) - Method in class org.apache.camel.builder.DataFormatClause
 
fhirXml(boolean) - Method in class org.apache.camel.builder.DataFormatClause
 
fhirXml(String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
 
FhirXmlDataFormat - Class in org.apache.camel.model.dataformat
The FHIR XML data format is used to marshall/unmarshall from/to FHIR objects to/from XML.
FhirXmlDataFormat() - Constructor for class org.apache.camel.model.dataformat.FhirXmlDataFormat
 
fileAbsoluteExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileAbsolutePathExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
FileDataSet - Class in org.apache.camel.component.dataset
A DataSet that reads payloads from a file that are used to create each message exchange along with using a pluggable transformer to customize the messages.
FileDataSet(String) - Constructor for class org.apache.camel.component.dataset.FileDataSet
 
FileDataSet(File) - Constructor for class org.apache.camel.component.dataset.FileDataSet
 
FileDataSet(String, String) - Constructor for class org.apache.camel.component.dataset.FileDataSet
 
FileDataSet(File, String) - Constructor for class org.apache.camel.component.dataset.FileDataSet
 
fileExtensionExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileExtensionSingleExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
FileLanguage - Class in org.apache.camel.language.simple
 
FileLanguage() - Constructor for class org.apache.camel.language.simple.FileLanguage
 
fileLastModifiedExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileNameExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileNameNoExtensionExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileNameNoExtensionSingleExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileOnlyNameExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileOnlyNameNoExtensionExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileOnlyNameNoExtensionSingleExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileParentExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
filePathExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
fileSizeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
 
FileStateRepository - Class in org.apache.camel.impl
This FileStateRepository class is a file-based implementation of a StateRepository.
FileStateRepository() - Constructor for class org.apache.camel.impl.FileStateRepository
 
FileStateRepository(File, Map<String, String>) - Constructor for class org.apache.camel.impl.FileStateRepository
 
fileStateRepository(File) - Static method in class org.apache.camel.impl.FileStateRepository
Creates a new file based repository using as 1st level cache
fileStateRepository(File, long) - Static method in class org.apache.camel.impl.FileStateRepository
Creates a new file based repository using a HashMap as 1st level cache.
fileStateRepository(File, Map<String, String>) - Static method in class org.apache.camel.impl.FileStateRepository
Creates a new file based repository using the given Map as 1st level cache.
fileWatchDirectory - Variable in class org.apache.camel.main.MainSupport
 
fileWatchDirectoryRecursively - Variable in class org.apache.camel.main.MainSupport
 
FileWatcherReloadStrategy - Class in org.apache.camel.impl
A file based ReloadStrategy which watches a file folder for modified files and reload on file changes.
FileWatcherReloadStrategy() - Constructor for class org.apache.camel.impl.FileWatcherReloadStrategy
 
FileWatcherReloadStrategy(String) - Constructor for class org.apache.camel.impl.FileWatcherReloadStrategy
 
FileWatcherReloadStrategy(String, boolean) - Constructor for class org.apache.camel.impl.FileWatcherReloadStrategy
 
filter(Predicate) - Method in class org.apache.camel.builder.NotifyBuilder
Optionally a filter to only allow matching Exchange to be used for matching.
filter() - Method in class org.apache.camel.builder.NotifyBuilder
Optionally a filter to only allow matching Exchange to be used for matching.
filter(String) - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
filter(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
Specified a filter to control what data gets merging data back from the claim check repository.
filter() - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate expression which only if it is true then the exchange is forwarded to the destination
filter(Predicate) - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate which is applied and only if it is true then the exchange is forwarded to the destination
filter(ExpressionDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate expression which only if it is true then the exchange is forwarded to the destination
filter(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate language expression which only if it is true then the exchange is forwarded to the destination
filter(OnExceptionDefinition, Class<?>, Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy to filter the given type exception class with the thrown exception
FilterDefinition - Class in org.apache.camel.model
Filter out messages based using a predicate
FilterDefinition() - Constructor for class org.apache.camel.model.FilterDefinition
 
FilterDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.FilterDefinition
 
FilterDefinition(Predicate) - Constructor for class org.apache.camel.model.FilterDefinition
 
FilterProcessor - Class in org.apache.camel.processor
The processor which implements the Message Filter EIP pattern.
FilterProcessor(Predicate, Processor) - Constructor for class org.apache.camel.processor.FilterProcessor
 
FilterResult(boolean, String) - Constructor for class org.apache.camel.impl.SupervisingRouteController.FilterResult
 
FilterResult(boolean, String, Object...) - Constructor for class org.apache.camel.impl.SupervisingRouteController.FilterResult
 
filterTypeInOutputs(List<ProcessorDefinition<?>>, Class<T>) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Looks for the given type in the list of outputs and recurring all the children as well.
filterTypeInOutputs(List<ProcessorDefinition<?>>, Class<T>, int) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Looks for the given type in the list of outputs and recurring all the children as well.
FinallyDefinition - Class in org.apache.camel.model
Path traversed when a try, catch, finally block exits
FinallyDefinition() - Constructor for class org.apache.camel.model.FinallyDefinition
 
FinallyProcessor - Class in org.apache.camel.processor
Processor to handle do finally supporting asynchronous routing engine
FinallyProcessor(Processor) - Constructor for class org.apache.camel.processor.FinallyProcessor
 
finallyProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
find(PackageScanFilter, String, Set<Class<?>>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
find(PackageScanFilter, String, ClassLoader, Set<Class<?>>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findAnnotated(Class<? extends Annotation>, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findBindingsByType(Class<T>) - Method in class org.apache.camel.main.MainRegistry
 
findByFilter(PackageScanFilter, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findClass(String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
findClass(String, String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
findClass(String, String, Class<?>) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
findComponents() - Method in class org.apache.camel.impl.AbstractCamelContext
 
findEips() - Method in class org.apache.camel.impl.AbstractCamelContext
 
findFirstParentOfType(Class<T>, ProcessorDefinition<?>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Is the given node parent(s) of the given type
findFirstTypeInOutputs(List<ProcessorDefinition<?>>, Class<T>) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Looks for the given type in the list of outputs and recurring all the children as well.
findImplementations(Class<?>, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findLanguage(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
findLanguageResolver(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
findOneWayAnnotation(Method) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the oneway annotation in priority order; look for method level annotations first, then the class level annotations, then super class annotations then interface annotations
findOneWayAnnotation(List<Class<?>>) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the first annotation on the given list of classes
findOneWayAnnotationOnMethod(List<Class<?>>, Method) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the first annotation on the base methods defined in the list of classes
findOrCreateCamelTemplate() - Method in class org.apache.camel.main.Main
 
findOrCreateCamelTemplate() - Method in class org.apache.camel.main.MainSupport
 
findSuitableException(Throwable, Method) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
Tries to find the best suited exception to throw.
first() - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
FlatpackDataFormat - Class in org.apache.camel.model.dataformat
The Flatpack data format is used for working with flat payloads (such as CSV, delimited, or fixed length formats).
FlatpackDataFormat() - Constructor for class org.apache.camel.model.dataformat.FlatpackDataFormat
 
flexible(Class<T>) - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a FlexibleAggregationStrategy pivoting around a particular type, e.g.
flexible() - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a FlexibleAggregationStrategy with no particular type, i.e.
FlexibleAggregationStrategy<E> - Class in org.apache.camel.builder
The Flexible Aggregation Strategy is a highly customizable, fluently configurable aggregation strategy.
FlexibleAggregationStrategy() - Constructor for class org.apache.camel.builder.FlexibleAggregationStrategy
Initializes a new instance with Object as the FlexibleAggregationStrategy.castAs type.
FlexibleAggregationStrategy(Class<E>) - Constructor for class org.apache.camel.builder.FlexibleAggregationStrategy
Initializes a new instance with the specified type as the FlexibleAggregationStrategy.castAs type.
FlexibleAggregationStrategy.CompletionAwareMixin - Interface in org.apache.camel.builder
 
FlexibleAggregationStrategy.TimeoutAwareMixin - Interface in org.apache.camel.builder
 
forceAssignIds(CamelContext, List<RouteDefinition>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Force assigning ids to the routes
forceAssignIds(CamelContext, ProcessorDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Force assigning ids to the give node and all its children (recursively).
forceCompletionOfAllGroups() - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force complete of all groups
forceCompletionOfAllGroups() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceCompletionOfAllGroups() - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceCompletionOfGroup(String) - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force completing a specific group by its key.
forceCompletionOfGroup(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceCompletionOfGroup(String) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceCompletionOnStop() - Method in class org.apache.camel.model.AggregateDefinition
Indicates to complete all current aggregated exchanges when the context is stopped
forceLazyInitialization() - Method in class org.apache.camel.impl.AbstractCamelContext
Force some lazy initialization to occur upfront before we start any components and create routes
forceShutdown(Service) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
forceStopLazyInitialization() - Method in class org.apache.camel.impl.AbstractCamelContext
Force clear lazy initialization so they can be re-created on restart
forNamespace(CamelContext, CamelClusterService.Selector, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
forNamespace(CamelContext, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
forNamespace(CamelClusterService, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
forNamespace(CamelClusterService.Selector, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
forNamespace(String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
forNamespace(String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
forNamespace(CamelClusterService.Selector, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
forNamespace(CamelClusterService, String) - Static method in class org.apache.camel.impl.cluster.ClusteredRoutePolicyFactory
 
forServices(Collection<ServiceDefinition>) - Static method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
 
forServices(ServiceDefinition...) - Static method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
 
forServices(Collection<ServiceDefinition>) - Static method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
forServices(ServiceDefinition...) - Static method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
from(String) - Method in class org.apache.camel.builder.NotifyBuilder
Optionally a from endpoint which means that this expression should only be based on Exchange which is originated from the particular endpoint(s).
from(String) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given URI input
from(Endpoint) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given endpoint
from(ServiceDefinition) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
from(Map<String, String>) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
from(String) - Method in class org.apache.camel.model.RouteDefinition
Creates an input to the route
from(Endpoint) - Method in class org.apache.camel.model.RouteDefinition
Creates an input to the route
from(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given URI input
from(Endpoint) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given endpoint
FromDefinition - Class in org.apache.camel.model
Act as a message source as input to a route
FromDefinition() - Constructor for class org.apache.camel.model.FromDefinition
 
FromDefinition(String) - Constructor for class org.apache.camel.model.FromDefinition
 
FromDefinition(Endpoint) - Constructor for class org.apache.camel.model.FromDefinition
 
fromEndpoint(Endpoint) - Static method in class org.apache.camel.model.RouteDefinition
 
fromF(String, Object...) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given URI input
fromRest(String) - Method in class org.apache.camel.model.RouteDefinition
This route is created from the REST DSL.
fromRoute(String) - Method in class org.apache.camel.builder.NotifyBuilder
Optionally a from route which means that this expression should only be based on Exchange which is originated from the particular route(s).
fromType(String) - Method in class org.apache.camel.builder.TransformerBuilder
Set the 'from' data type name.
fromType(Class<?>) - Method in class org.apache.camel.builder.TransformerBuilder
Set the 'from' data type using Java class.
fromUri(String) - Static method in class org.apache.camel.model.RouteDefinition
 
FUNCTION_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
functionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the XPathFunctionResolver instance to use on these XPath expressions
functionText() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
functionText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 

G

gatherAllEndpointUris(CamelContext, RouteDefinition, boolean, boolean, boolean) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Gather all the endpoint uri's the route is using from the EIPs that has a static or dynamic endpoint defined.
gatherAllNodeIds(ProcessorDefinition<?>, Set<String>, boolean, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Traverses the node, including its children (recursive), and gathers all the node ids.
gatherAllStaticEndpointUris(CamelContext, RouteDefinition, boolean, boolean) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Gather all the endpoint uri's the route is using from the EIPs that has a static endpoint defined.
gatherEndpoints() - Method in class org.apache.camel.impl.RouteService
Gather all the endpoints this route service uses

This implementation finds the endpoints by searching all the child services for EndpointAware processors which uses an endpoint.

generateSanitizedId() - Method in class org.apache.camel.impl.DefaultUuidGenerator
Generate a unique ID - that is friendly for a URL or file system
generateSanitizedId(String) - Static method in class org.apache.camel.impl.DefaultUuidGenerator
Ensures that the id is friendly for a URL or file system
generateUuid() - Method in class org.apache.camel.impl.DefaultUuidGenerator
 
generateUuid() - Method in class org.apache.camel.impl.JavaUuidGenerator
 
get(Object) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
get(String) - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
get() - Method in interface org.apache.camel.impl.DefaultFactoryFinder.ClassSupplier
 
get() - Method in class org.apache.camel.model.rest.RestDefinition
 
get(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
get() - Method in class org.apache.camel.model.rest.VerbDefinition
 
get(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
get(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
getAbbreviation() - Method in class org.apache.camel.main.MainSupport.Option
 
getAclToken() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getAction() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
getAction() - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
 
getAddKeyValueForEncryptedKey() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getAdvice(Class<T>) - Method in class org.apache.camel.processor.CamelInternalProcessor
Gets the advice with the given type.
getAdviceWithTasks() - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Gets a list of additional tasks to execute after the RouteBuilder.configure() method has been executed during the advice process.
getAggregateController() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregateController() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregateControllerRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregateOnException() - Method in class org.apache.camel.model.EnrichDefinition
 
getAggregateOnException() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAggregationRepository() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregationRepositoryRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.EnrichDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.MulticastDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.RecipientListDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.SplitDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.Enricher
 
getAggregationStrategy(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.MulticastProcessor
getAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
 
getAggregationStrategy() - Method in class org.apache.camel.processor.RecipientList
 
getAggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.EnrichDefinition
 
getAggregationStrategyMethodAllowNull() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAggregationStrategyMethodName() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategyMethodName() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getAggregationStrategyMethodName() - Method in class org.apache.camel.model.EnrichDefinition
 
getAggregationStrategyMethodName() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAggregationStrategyRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategyRef() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getAggregationStrategyRef() - Method in class org.apache.camel.model.EnrichDefinition
 
getAggregationStrategyRef() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAlgorithm() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getAlgorithm() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getAlgorithmParameterRef() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getAliases() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getAllEndpoints(boolean) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
getAllowableValues() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getAllowableValues() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getAllowCoreThreadTimeOut() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getAllowCoreThreadTimeOut() - Method in class org.apache.camel.model.ThreadsDefinition
 
getAllowDuplicates() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getAllowEasyPredicate() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getAllowEmptyDirectory() - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
 
getAllowEmptyDirectory() - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
 
getAllowJmsType() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getAllowJmsType() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getAllowMaximumSizeToDivergeFromCoreSize() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getAllowMissingColumnNames() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getAllowOptimisedComponents() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getAllowRedeliveryWhileStopping() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getAllowShortLines() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getAllowSimple() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getAllowUnmarshallType() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getAllowUnmarshallType() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getAndIncrement(NamedNode) - Method in class org.apache.camel.impl.DefaultRouteContext
 
getAndRemove(String) - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
getAndRemoveBooleanHeader(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAndRemoveBooleanProperty(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAnnotationObjectValue(Annotation, String) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
getAnnotations() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getApiComponent() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiContextIdPattern() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiContextListing() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiContextPath() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiContextRouteId() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiDocs() - Method in class org.apache.camel.model.rest.RestDefinition
 
getApiDocs() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getApiHost() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiProperties() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiVendorExtension() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getApiVersion() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getApplicationContextClassLoader() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getApplicationContextClassLoader() - Method in class org.apache.camel.impl.DefaultClassResolver
 
getArgs() - Method in class org.apache.camel.component.bean.BeanInvocation
 
getArguments() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getArmored() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getArrayType() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getArrayType() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getAsMap() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getAsyncDelayed() - Method in class org.apache.camel.model.DelayDefinition
 
getAsyncDelayed() - Method in class org.apache.camel.model.ThrottleDefinition
 
getAsyncDelayedRedelivery() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getAsyncProcessorAwaitManager() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getAttributes() - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
getAuthorizationUrl() - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
getAutoStartup() - Method in class org.apache.camel.model.RouteDefinition
Whether to auto start this route
getBacklogDebugger(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogDebugger
A helper method to return the BacklogDebugger instance if one is enabled
getBacklogSize() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getBacklogTracer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogTracer
A helper method to return the BacklogTracer instance if one is enabled
getBackOff(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
getBackOffConfigurations() - Method in class org.apache.camel.impl.SupervisingRouteController
 
getBackOffContext(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
getBackOffMultiplier() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getBackOffMultiplier() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getBarcodeFormat() - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
 
getBasePath() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getBatchConfig() - Method in class org.apache.camel.model.ResequenceDefinition
 
getBatchSize() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getBatchTimeout() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getBatchTimeout() - Method in class org.apache.camel.processor.Resequencer
 
getBean() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
getBean() - Method in interface org.apache.camel.component.bean.BeanHolder
Gets the bean.
getBean() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getBean() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBean() - Method in class org.apache.camel.component.bean.ConstantStaticTypeBeanHolder
 
getBean() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
getBean() - Method in exception org.apache.camel.component.bean.MethodNotFoundException
 
getBean() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBean() - Method in class org.apache.camel.model.BeanDefinition
 
getBeanClass() - Method in class org.apache.camel.model.BeanDefinition
 
getBeanHolder() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
getBeanHolder() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getBeanHolder() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getBeanInfo() - Method in interface org.apache.camel.component.bean.BeanHolder
Gets bean info for the bean.
getBeanInfo(Object) - Method in interface org.apache.camel.component.bean.BeanHolder
Gets bean info for the given bean.
getBeanInfo() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBeanInfo(Object) - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBeanInfo() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
getBeanInfo(Object) - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
getBeanInfo(Class<?>) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
getBeanInfo() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBeanInfo(Object) - Method in class org.apache.camel.component.bean.RegistryBean
 
getBeanName() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getBeanName() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getBeanPostProcessor() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getBeanReaderErrorHandlerType() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getBeanType() - Method in class org.apache.camel.model.BeanDefinition
 
getBeanType() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getBeanTypeName() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getBinaryContent() - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
getBindingMode() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getBindingMode() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getBindingMode() - Method in class org.apache.camel.model.rest.RestDefinition
 
getBindingMode() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getBindingName() - Method in class org.apache.camel.model.dataformat.JibxDataFormat
 
getBlockSeconds() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getBodyFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for getting the input message body.
getBodyMaxChars() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getBodyMaxChars() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getBodyParameters() - Method in class org.apache.camel.component.bean.MethodInfo
 
getBodyParameterType() - Method in class org.apache.camel.component.bean.MethodInfo
 
getBooleanProperty(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getBreakpoints() - Method in class org.apache.camel.impl.DefaultDebugger
 
getBreakpoints() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getBufferSize() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getBuffersize() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getCaCertData() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getCaCertFile() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getCache() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
getCache() - Method in class org.apache.camel.component.bean.BeanComponent
 
getCache() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getCache() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getCache() - Method in class org.apache.camel.impl.FileStateRepository
 
getCache() - Method in class org.apache.camel.model.BeanDefinition
 
getCacheSize() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getCacheSize() - Method in class org.apache.camel.model.EnrichDefinition
 
getCacheSize() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getCacheSize() - Method in class org.apache.camel.model.RecipientListDefinition
 
getCacheSize() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getCacheSize() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getCacheSize() - Method in class org.apache.camel.processor.Enricher
 
getCacheSize() - Method in class org.apache.camel.processor.PollEnricher
 
getCacheSize() - Method in class org.apache.camel.processor.RecipientList
 
getCacheSize() - Method in class org.apache.camel.processor.RoutingSlip
 
getCacheSize() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getCacheSize() - Method in class org.apache.camel.processor.WireTapProcessor
 
getCallerRunsWhenRejected() - Method in class org.apache.camel.model.DelayDefinition
 
getCallerRunsWhenRejected() - Method in class org.apache.camel.model.ThreadsDefinition
 
getCallerRunsWhenRejected() - Method in class org.apache.camel.model.ThrottleDefinition
 
getCamelContext() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
getCamelContext() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getCamelContext() - Method in class org.apache.camel.component.bean.BeanInfo
 
getCamelContext() - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getCamelContext() - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
getCamelContext() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
getCamelContext() - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
getCamelContext() - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultClassResolver
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultDebugger
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultProducerCache
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultRouteController
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
getCamelContext() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
getCamelContext() - Method in class org.apache.camel.impl.RouteService
 
getCamelContext() - Method in class org.apache.camel.main.MainSupport
 
getCamelContext() - Method in class org.apache.camel.model.rest.RestsDefinition
 
getCamelContext() - Method in class org.apache.camel.model.RoutesDefinition
 
getCamelContext() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
getCamelContext() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
getCamelContext() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.Enricher
 
getCamelContext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getCamelContext() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getCamelContext() - Method in class org.apache.camel.processor.MulticastProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.PollEnricher
 
getCamelContext() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.WireTapProcessor
 
getCamelTemplate() - Method in class org.apache.camel.main.MainSupport
 
getCapacity() - Method in class org.apache.camel.impl.DefaultConsumerCache
Gets the maximum cache size (capacity).
getCapacity() - Method in class org.apache.camel.impl.DefaultProducerCache
Gets the maximum cache size (capacity).
getCapacity() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getCapacity() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's capacity.
getCatchClauses() - Method in class org.apache.camel.model.TryDefinition
 
getCharset() - Method in class org.apache.camel.impl.StringDataFormat
 
getCharset() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getCharset() - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
getCharset() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getChildren() - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
getCircuitBreakerEnabled() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCircuitBreakerErrorThresholdPercentage() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCircuitBreakerForceClosed() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCircuitBreakerForceOpen() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCircuitBreakerRequestVolumeThreshold() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCircuitBreakerSleepWindowInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getClassLoader(Class<?>...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Returns the class loader of the first interface or throws IllegalArgumentException if there are no interfaces specified
getClassLoader() - Method in class org.apache.camel.impl.DefaultModelJAXBContextFactory
 
getClassLoader() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getClassLoaders() - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
getClassName() - Method in class org.apache.camel.model.transformer.CustomTransformerDefinition
 
getClassName() - Method in class org.apache.camel.model.validator.CustomValidatorDefinition
 
getClassResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getClassType() - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
getClazzName() - Method in class org.apache.camel.model.dataformat.ASN1DataFormat
 
getClientCertData() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientCertFile() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientKeyAlgo() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientKeyData() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientKeyFile() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientKeyPassphrase() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getClientName() - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
getClientRequestValidation() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getClientRequestValidation() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getClientRequestValidation() - Method in class org.apache.camel.model.rest.RestDefinition
 
getClientRequestValidation() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getCloseCorrelationKeyOnCompletion() - Method in class org.apache.camel.model.AggregateDefinition
 
getCloseCorrelationKeyOnCompletion() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getClosedCorrelationKeysCacheSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Current number of closed correlation keys in the memory cache
getClsName() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
getClsName() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterEntry
 
getClsName() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
getClsName() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
getClusterService() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getClusterServiceSelector() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getCode() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
getCollectionFormat() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getCollectionFormat() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getCollectionTypeName() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getCollectionTypeName() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getCollisionAvoidancePercent() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getComment() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getCommentMarker() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getCommentMarkerDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getComparator() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getComparator() - Method in class org.apache.camel.model.SortDefinition
 
getComparator() - Method in class org.apache.camel.processor.SortProcessor
 
getComparatorRef() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getComparatorRef() - Method in class org.apache.camel.model.SortDefinition
 
getCompensation() - Method in class org.apache.camel.model.SagaDefinition
 
getCompleteAllOnStop() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletedByBatchConsumer() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion batch consumer trigger
getCompletedByForce() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion force trigger
getCompletedByInterval() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion interval trigger
getCompletedByPredicate() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion predicate trigger
getCompletedBySize() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion size trigger
getCompletedByStrategy() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion strategy trigger
getCompletedByTimeout() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion timeout trigger
getCompletion() - Method in class org.apache.camel.model.SagaDefinition
 
getCompletionEager() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getCompletionFromBatchConsumer() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionInterval() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionMode() - Method in class org.apache.camel.model.SagaDefinition
 
getCompletionOnNewCorrelationGroup() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionPredicate() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionPredicate() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionPredicate() - Method in class org.apache.camel.processor.Resequencer
 
getCompletionSize() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionSizeExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionSizeExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeout() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutCheckerInterval() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionTimeoutCheckerInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getCompletionTimeoutExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getComponent(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponent(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponent(String, boolean, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponent(String, Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponent() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getComponent() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getComponent() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getComponent() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getComponentNames() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponentParameterJsonSchema(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getComponentProperties() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getComponentResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getCompressionAlgorithm() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getCompressionLevel() - Method in class org.apache.camel.impl.ZipDataFormat
 
getCompressionLevel() - Method in class org.apache.camel.model.dataformat.ZipDataFormat
 
getConfigurationClasses() - Method in class org.apache.camel.main.MainSupport
 
getConfigurationRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getConfigurations() - Method in class org.apache.camel.main.MainSupport
 
getConfiguredExecutorService(RouteContext, String, ExecutorServiceAwareDefinition<?>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Will lookup and get the configured ExecutorService from the given definition.
getConfiguredScheduledExecutorService(RouteContext, String, ExecutorServiceAwareDefinition<?>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Will lookup and get the configured ScheduledExecutorService from the given definition.
getConnectionTimeout() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getConnectTimeoutMillis() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getConstructor() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getConsumeDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getConsumer() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
getConsumerProcessor(Endpoint) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getConsumerProperties() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getConsumes() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getConsumes() - Method in class org.apache.camel.model.rest.RestDefinition
 
getConsumes() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getContentTypeFormat() - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
 
getContentTypeFormat() - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
 
getContentTypeHeader() - Method in class org.apache.camel.model.DataFormatDefinition
 
getContext() - Method in class org.apache.camel.builder.BuilderSupport
 
getContext() - Method in class org.apache.camel.component.bean.RegistryBean
 
getContextPath() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getContextPath() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getContextPath() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getContextPath() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getContinued() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getContinuedPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getControlledRoutes() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getControlledRoutes() - Method in class org.apache.camel.impl.DefaultRouteController
 
getControlledRoutes() - Method in class org.apache.camel.impl.SupervisingRouteController
 
getConverters() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getCopy() - Method in class org.apache.camel.model.LoopDefinition
 
getCopy() - Method in class org.apache.camel.model.WireTapDefinition
 
getCorePoolSize() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getCorrelationExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getCorrelationExpression() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
getCorrelationExpression() - Method in class org.apache.camel.model.ThrottleDefinition
 
getCorrelationExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCorrelationExpression() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getCorrelationKey() - Method in exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
getCorsHeaders() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getCounter() - Method in class org.apache.camel.processor.SendProcessor
 
getCryptoProvider() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getCurrentCacheSize() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
getCurrentCacheSize() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
getCurrentCacheSize() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getCurrentMaximumRequestsPerPeriod() - Method in class org.apache.camel.processor.Throttler
Gets the current maximum request per period value.
getCurrentSagaCoordinator(Exchange) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getCurrentShutdownTaskFuture() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
getCustomId() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
 
getCustomLoadBalancer() - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
 
getDatacenter() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getDataFormat(RouteContext, DataFormatDefinition, String) - Static method in class org.apache.camel.model.DataFormatDefinition
Factory method to create the data format
getDataFormat(RouteContext) - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormat() - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormat() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getDataFormat() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getDataFormatName() - Method in class org.apache.camel.impl.GzipDataFormat
 
getDataFormatName() - Method in class org.apache.camel.impl.SerializationDataFormat
 
getDataFormatName() - Method in class org.apache.camel.impl.StringDataFormat
 
getDataFormatName() - Method in class org.apache.camel.impl.ZipDataFormat
 
getDataFormatName() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getDataFormatName() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getDataFormatName() - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormatParameterJsonSchema(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDataFormatProperties() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getDataFormatResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDataFormats() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDataFormats() - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
 
getDataFormats() - Method in interface org.apache.camel.model.ModelCamelContext
Gets the data formats that can be referenced in the routes.
getDataFormatType() - Method in class org.apache.camel.model.MarshalDefinition
 
getDataFormatType() - Method in class org.apache.camel.model.transformer.DataFormatTransformerDefinition
 
getDataFormatType() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getDataObjectType() - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
getDataObjectTypeName() - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
getDataSet() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getDataSetIndex() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getDataType() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getDataType() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getDeadLetter() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getDeadLetter() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Returns the dead letter that message exchanges will be sent to if the redelivery attempts fail
getDeadLetterUri() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getDeadLetterUri() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getDebugCounter() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getDebugger() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDebugger() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getDefault() - Static method in class org.apache.camel.model.config.BatchResequencerConfig
Returns a new BatchResequencerConfig instance using default values for batchSize (100) and batchTimeout (1000L).
getDefault() - Static method in class org.apache.camel.model.config.StreamResequencerConfig
Returns a new StreamResequencerConfig instance using default values for capacity (1000) and timeout (1000L).
getDefaultBackOff() - Method in class org.apache.camel.impl.SupervisingRouteController
 
getDefaultBodies() - Method in class org.apache.camel.component.dataset.ListDataSet
 
getDefaultBody() - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
getDefaultEndpoint() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
getDefaultEndpoint() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getDefaultFactoryFinder() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDefaultHandledPredicate() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getDefaultHeaders() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getDefaultInstance() - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
 
getDefaultInstance() - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
 
getDefaultParameterTypeExpression(Class<?>) - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
 
getDefaultParameterTypeExpression(Class<?>) - Method in interface org.apache.camel.component.bean.ParameterMappingStrategy
Gets an expression used for evaluation with the current Exchange and its result is used as parameter value for the given type
getDefaultProfile() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getDefaultThreadPoolProfile() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
getDefaultValue() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter default value.
getDefaultValues() - Method in class org.apache.camel.model.rest.RestBindingDefinition
Gets the registered default values for query parameters
getDefinition() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getDelay() - Method in class org.apache.camel.processor.Delayer
 
getDelayedCount() - Method in class org.apache.camel.processor.DelayProcessorSupport
Gets the current number of Exchanges being delayed (hold back due throttle limit hit)
getDelayer() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getDelayer() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getDelayer() - Method in class org.apache.camel.model.RouteDefinition
Whether to slow down processing messages by a given delay in msec.
getDelayPattern() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getDelayPattern() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getDelayValue() - Method in class org.apache.camel.processor.Delayer
 
getDelegate() - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
getDelegate() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
getDelegates() - Method in class org.apache.camel.impl.cloud.CombinedServiceDiscovery
 
getDelegates() - Method in class org.apache.camel.impl.cloud.CombinedServiceFilter
 
getDelimiter() - Method in class org.apache.camel.component.dataset.FileDataSet
 
getDelimiter() - Method in class org.apache.camel.component.test.TestEndpoint
 
getDelimiter() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getDelimiter() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getDelimiter() - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
getDelimiter() - Method in class org.apache.camel.model.RecipientListDefinition
 
getDelimiter() - Method in class org.apache.camel.processor.RecipientList
 
getDeliveryAttemptInterval() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getDescription() - Method in class org.apache.camel.impl.DefaultRoute
 
getDescription() - Method in class org.apache.camel.main.MainSupport.Option
 
getDescription() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
 
getDescription() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getDescription() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getDescription() - Method in class org.apache.camel.model.rest.RestSecurityDefinition
 
getDescriptionText() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Returns the description text or null if there is no description text associated with this node
getDestination() - Method in class org.apache.camel.processor.SendProcessor
 
getDetour() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
getDigestAlgorithm() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getDisableFeatures() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getDisableFeatures() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getDisableRedelivery() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getDiscardOnCompletionTimeout() - Method in class org.apache.camel.model.AggregateDefinition
 
getDistributionRatio() - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
 
getDistributionRatioDelimiter() - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
 
getDistributionWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getDnsDomain() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getDocument(Exchange, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Strategy method to extract the document from the exchange.
getDocumentType() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getDocumentType() - Method in class org.apache.camel.model.language.XPathExpression
 
getDocumentTypeName() - Method in class org.apache.camel.model.language.XPathExpression
 
getDomain() - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
 
getDontEncodeElements() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getDontStripVersionsFromReferencesAtPaths() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getDoWhile() - Method in class org.apache.camel.model.LoopDefinition
 
getDriver() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getDriverRef() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getDumperOptions() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getDuration() - Method in class org.apache.camel.main.MainSupport
 
getDurationHitExitCode() - Method in class org.apache.camel.main.MainSupport
 
getDurationIdle() - Method in class org.apache.camel.main.MainSupport
 
getDurationMaxMessages() - Method in class org.apache.camel.main.MainSupport
 
getDynamicAware() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getDynamicUri() - Method in class org.apache.camel.model.WireTapDefinition
 
getEager() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getEagerCheckCompletion() - Method in class org.apache.camel.model.AggregateDefinition
 
getEipParameterJsonSchema(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getElementNameStrategy() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getElementNameStrategyRef() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getEmptyValue() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getEnableCORS() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getEnableCORS() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getEnableCORS() - Method in class org.apache.camel.model.rest.RestDefinition
 
getEnableCORS() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getEnableFeatures() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getEnableFeatures() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getEnableJaxbAnnotationModule() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getEnableJaxbAnnotationModule() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getEncodeElements() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getEncoding() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getEncoding() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getEncoding() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getEncoding() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getEndpoint(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getEndpoint(String, Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getEndpoint() - Method in class org.apache.camel.impl.DefaultRoute
 
getEndpoint() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getEndpoint() - Method in class org.apache.camel.impl.DeferProducer
 
getEndpoint() - Method in class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
getEndpoint() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
getEndpoint() - Method in class org.apache.camel.model.FromDefinition
Gets tne endpoint if an Endpoint instance was set.
getEndpoint() - Method in class org.apache.camel.model.SendDefinition
Gets tne endpoint if an Endpoint instance was set.
getEndpoint() - Method in class org.apache.camel.processor.EventNotifierProducer
 
getEndpoint() - Method in class org.apache.camel.processor.SendProcessor
 
getEndpoint() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
getEndpointInjection(Object, String, String, String, boolean) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getEndpointKey(String) - Method in class org.apache.camel.impl.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointKey(String, Endpoint) - Method in class org.apache.camel.impl.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointKey() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
getEndpointKeyPreNormalized(String) - Method in class org.apache.camel.impl.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointMap() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getEndpointProperties() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getEndpointRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getEndpoints() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getEndpointsPerRoute(String, boolean) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
getEndpointStatistics() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
getEndpointUri() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
getEndpointUri() - Method in interface org.apache.camel.model.EndpointRequiredDefinition
Gets the uri of the endpoint used by this definition.
getEndpointUri() - Method in class org.apache.camel.model.FromDefinition
 
getEndpointUri() - Method in class org.apache.camel.model.SendDefinition
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.impl.DefaultProducerCache
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.Enricher
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.PollEnricher
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.RecipientList
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.RoutingSlip
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.WireTapProcessor
 
getEndToken() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getEndToken() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getErrorHandler(String) - Method in class org.apache.camel.model.OnExceptionDefinition
 
getErrorHandler() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
 
getErrorHandlerBuilder() - Method in class org.apache.camel.builder.BuilderSupport
 
getErrorHandlerBuilder() - Method in class org.apache.camel.model.RouteDefinition
 
getErrorHandlerExecutorService() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getErrorHandlerFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getErrorHandlerFactory() - Method in class org.apache.camel.model.RoutesDefinition
 
getErrorHandlerRef() - Method in class org.apache.camel.model.RouteDefinition
Sets the bean ref name of the error handler builder to use on this route
getErrorHandlers(RouteContext) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Gets the error handlers
getErrorHandlers(RouteContext) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
getErrorHandlers() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getEscape() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getEscapeChar() - Method in class org.apache.camel.model.dataformat.UniVocityTsvDataFormat
 
getEscapeDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getEventFactory() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getEventNotifiers() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getEvicted() - Method in class org.apache.camel.impl.DefaultConsumerCache
Gets the cache evicted statistic

Will return -1 if it cannot determine this if a custom cache was used.

getEvicted() - Method in class org.apache.camel.impl.DefaultProducerCache
Gets the cache evicted statistic

Will return -1 if it cannot determine this if a custom cache was used.

getEvicted() - Method in class org.apache.camel.impl.ServicePool
 
getExample() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getExamples() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getExamples() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
getException() - Method in class org.apache.camel.impl.DefaultRouteError
 
getException() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getException() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getExceptionClass() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getExceptionClass() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
getExceptionClasses() - Method in class org.apache.camel.model.CatchDefinition
 
getExceptionClasses() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getExceptionFailureStatistics() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getExceptionHandler() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getExceptionHandler() - Method in class org.apache.camel.processor.Resequencer
 
getExceptionHandler() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's exception handler.
getExceptionPolicy(Exchange, Throwable) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Attempts to find the best suited OnExceptionDefinition to be used for handling the given thrown exception.
getExceptionPolicy(Map<ExceptionPolicyKey, OnExceptionDefinition>, Exchange, Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
 
getExceptionPolicy(Map<ExceptionPolicyKey, OnExceptionDefinition>, Exchange, Throwable) - Method in interface org.apache.camel.processor.exceptionpolicy.ExceptionPolicyStrategy
Resolves the OnExceptionDefinition that should handle the thrown exception.
getExceptionPolicyStrategy() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Gets the exception policy strategy
getExceptionPolicyStrategy() - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
getExceptions() - Method in class org.apache.camel.impl.DefaultSubUnitOfWork
 
getExceptions() - Method in class org.apache.camel.model.CatchDefinition
 
getExceptions() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getExceptions() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getExceptions() - Method in class org.apache.camel.processor.CatchProcessor
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getExceptionType() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getExceptionTypes() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getExchange() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getExchange() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The exchange which caused this failure
getExchange() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getExchangeFormatterRef() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getExchangeFormatterRef() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getExchangeIndex(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
getExchangeIndex(Exchange) - Method in class org.apache.camel.processor.Splitter
 
getExchangePattern() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getExchangePattern() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
getExchanges() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExcludePattern() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
getExcludePattern() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
getExcludePattern() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getExcludePattern() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getExcludePatterns() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
getExcludePatterns() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
getExcludes() - Method in class org.apache.camel.model.ContextScanDefinition
 
getExcludes() - Method in class org.apache.camel.model.PackageScanDefinition
 
getExecutionIsolationSemaphoreMaxConcurrentRequests() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getExecutionIsolationStrategy() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getExecutionIsolationThreadInterruptOnTimeout() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getExecutionTimeoutEnabled() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getExecutionTimeoutInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getExecutorService(CamelContext) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getExecutorService(CamelContext) - Static method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
getExecutorService() - Method in class org.apache.camel.model.AggregateDefinition
 
getExecutorService() - Method in class org.apache.camel.model.DelayDefinition
 
getExecutorService() - Method in class org.apache.camel.model.MulticastDefinition
 
getExecutorService() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getExecutorService() - Method in class org.apache.camel.model.RecipientListDefinition
 
getExecutorService() - Method in class org.apache.camel.model.SplitDefinition
 
getExecutorService() - Method in class org.apache.camel.model.ThreadsDefinition
 
getExecutorService() - Method in class org.apache.camel.model.ThrottleDefinition
 
getExecutorService() - Method in class org.apache.camel.model.WireTapDefinition
 
getExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
getExecutorService() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getExecutorServiceManager() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getExecutorServiceRef() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getExecutorServiceRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.DelayDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.MulticastDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.RecipientListDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.SplitDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.ThreadsDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.ThrottleDefinition
 
getExecutorServiceRef() - Method in class org.apache.camel.model.WireTapDefinition
 
getExitCode() - Method in class org.apache.camel.main.MainSupport
 
getExpectedCount() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExpectedMinimumCount() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExponentialBackOff() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
getExpression() - Method in class org.apache.camel.builder.ValueBuilder
 
getExpression() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getExpression() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getExpression() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getExpression() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getExpression() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getExpression() - Method in class org.apache.camel.model.ExpressionNode
 
getExpression() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getExpression() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getExpression() - Method in class org.apache.camel.model.ResequenceDefinition
 
getExpression() - Method in class org.apache.camel.model.SagaOptionDefinition
 
getExpression() - Method in class org.apache.camel.model.validator.PredicateValidatorDefinition
 
getExpression() - Method in class org.apache.camel.processor.Enricher
 
getExpression() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The expression which was used
getExpression() - Method in class org.apache.camel.processor.LogProcessor
 
getExpression() - Method in class org.apache.camel.processor.LoopProcessor
 
getExpression() - Method in class org.apache.camel.processor.PollEnricher
 
getExpression() - Method in class org.apache.camel.processor.RecipientList
 
getExpression() - Method in class org.apache.camel.processor.Resequencer
 
getExpression() - Method in class org.apache.camel.processor.RoutingSlip
 
getExpression() - Method in class org.apache.camel.processor.ScriptProcessor
 
getExpression() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getExpression() - Method in class org.apache.camel.processor.SortProcessor
 
getExpression() - Method in class org.apache.camel.processor.Splitter
 
getExpression() - Method in class org.apache.camel.processor.StreamResequencer
 
getExpression() - Method in class org.apache.camel.processor.TransformProcessor
 
getExpressionConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getExpressionConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getExpressionFromAnnotation(Annotation) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
getExpressionNameSpacePrefix(Annotation) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
getExpressionRef() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getExpressionRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getExpressionType() - Method in class org.apache.camel.builder.ExpressionClause
 
getExpressionType() - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
getExpressionType() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getExpressionType() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getExpressionType() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getExpressionValue() - Method in class org.apache.camel.builder.ExpressionClause
 
getExpressionValue() - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
getExpressionValue() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getExtension(Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getFactoryClassName() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getFactoryFinder(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getFactoryFinderResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getFactoryRef() - Method in class org.apache.camel.model.language.XPathExpression
 
getFailedCounter() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
getFailureCounter(Class<?>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
getFailureProcessor() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getFailureProcessor() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getFailures() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getFallbackEnabled() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getFallbackIsolationSemaphoreMaxConcurrentRequests() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getFallbackTimeout() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getFallbackViaNetwork() - Method in class org.apache.camel.model.OnFallbackDefinition
 
getFhirContext() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getFhirVersion() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getFields() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
getFields() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
getFilePath() - Method in class org.apache.camel.impl.FileStateRepository
 
getFileStore() - Method in class org.apache.camel.impl.FileStateRepository
 
getFileWatchDirectory() - Method in class org.apache.camel.main.MainSupport
 
getFilter() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getFilter() - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
getFilter() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getFilteredCount() - Method in class org.apache.camel.processor.FilterProcessor
Gets the number of Exchanges that matched the filter predicate and therefore as filtered.
getFilterNonXmlChars() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getFilters() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getFilters() - Method in class org.apache.camel.impl.SupervisingRouteController
 
getFilters() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getFinallyClause() - Method in class org.apache.camel.model.TryDefinition
 
getFixed() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getFlow() - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
getFolder() - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
getForceCompletionOnStop() - Method in class org.apache.camel.model.AggregateDefinition
 
getForceResourceId() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getFormatName() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getFormatRef() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getFragment() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getFrom() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getFrom() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getFromAnnotation(Annotation, String) - Method in class org.apache.camel.component.bean.BeanAnnotationExpressionFactory
 
getFromRouteId() - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
 
getFromType() - Method in class org.apache.camel.model.transformer.TransformerDefinition
 
getFullName() - Method in class org.apache.camel.main.MainSupport.Option
 
getFunctionResolver() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getGenericType(CamelContext, Type) - Static method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
getGlobalOption(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getGlobalOptions() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getGlobalOptions() - Method in class org.apache.camel.model.GlobalOptionsDefinition
 
getGroup() - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
getGroup() - Method in class org.apache.camel.impl.DefaultRoute
 
getGroup() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getGroup() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
getGroup() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getGroup() - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
getGroup() - Method in class org.apache.camel.model.RouteDefinition
The group that this route belongs to; could be the name of the RouteBuilder class or be explicitly configured in the XML.
getGroupKey() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getHandled() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getHandledPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getHandleFault() - Method in class org.apache.camel.model.RouteDefinition
Whether handle fault is enabled on this route.
getHandleFault(CamelContext) - Static method in class org.apache.camel.processor.interceptor.HandleFault
A helper method to return the HandleFault instance for a given CamelContext if one is enabled
getHashAlgorithm() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getHeader() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getHeaderDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Use for disabling headers
getHeaderExtractionEnabled() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for getting the input message header.
getHeaderName() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getHeaderName(Annotation) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
Extracts the value of the header method in the Annotation.
getHeaderName() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getHeaderName() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
getHeaderName() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getHeaderName() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getHeaderName() - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
getHeaderName() - Method in class org.apache.camel.model.language.XPathExpression
 
getHeaderName() - Method in class org.apache.camel.model.language.XQueryExpression
 
getHeaderName() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
getHeaderName() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getHeaderName() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getHeaderName() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getHeaders() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getHeaders() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
getHeaders() - Method in class org.apache.camel.model.WireTapDefinition
 
getHeadersDisabled() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getHeadersInline() - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
getHeadersMapFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getHealth() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getHeight() - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
 
getHits() - Method in class org.apache.camel.impl.DefaultConsumerCache
Gets the cache hits statistic

Will return -1 if it cannot determine this if a custom cache was used.

getHits() - Method in class org.apache.camel.impl.DefaultProducerCache
Gets the cache hits statistic

Will return -1 if it cannot determine this if a custom cache was used.

getHits() - Method in class org.apache.camel.impl.ServicePool
 
getHost() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getHost() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getHostHeader() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getHostName() - Static method in class org.apache.camel.impl.DefaultUuidGenerator
As we have to find the hostname as a side-affect of generating a unique stub, we allow it's easy retrieval here
getHostNameResolver() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getHystrixConfiguration(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getHystrixConfiguration() - Method in class org.apache.camel.model.HystrixDefinition
 
getHystrixConfiguration(String) - Method in interface org.apache.camel.model.ModelCamelContext
Gets the Hystrix configuration by the given name.
getHystrixConfigurationRef() - Method in class org.apache.camel.model.HystrixDefinition
 
getId() - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
getId() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getId() - Method in class org.apache.camel.impl.DefaultRoute
 
getId() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getId() - Method in class org.apache.camel.impl.RouteService
 
getId() - Method in class org.apache.camel.model.IdentifiedType
Gets the value of the id property.
getId() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getId() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
 
getId() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getId() - Method in class org.apache.camel.processor.CatchProcessor
 
getId() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getId() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getId() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getId() - Method in class org.apache.camel.processor.Delayer
 
getId() - Method in class org.apache.camel.processor.Enricher
 
getId() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
getId() - Method in class org.apache.camel.processor.FilterProcessor
 
getId() - Method in class org.apache.camel.processor.FinallyProcessor
 
getId() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getId() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getId() - Method in class org.apache.camel.processor.LogProcessor
 
getId() - Method in class org.apache.camel.processor.LoopProcessor
 
getId() - Method in class org.apache.camel.processor.MulticastProcessor
 
getId() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getId() - Method in class org.apache.camel.processor.Pipeline
 
getId() - Method in class org.apache.camel.processor.PollEnricher
 
getId() - Method in class org.apache.camel.processor.RecipientList
 
getId() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getId() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getId() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getId() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getId() - Method in class org.apache.camel.processor.Resequencer
 
getId() - Method in class org.apache.camel.processor.RollbackProcessor
 
getId() - Method in class org.apache.camel.processor.RoutingSlip
 
getId() - Method in class org.apache.camel.processor.SamplingThrottler
 
getId() - Method in class org.apache.camel.processor.ScriptProcessor
 
getId() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getId() - Method in class org.apache.camel.processor.SendProcessor
 
getId() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getId() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getId() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getId() - Method in class org.apache.camel.processor.SortProcessor
 
getId() - Method in class org.apache.camel.processor.StopProcessor
 
getId() - Method in class org.apache.camel.processor.StreamResequencer
 
getId() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getId() - Method in class org.apache.camel.processor.Throttler
 
getId() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getId() - Method in class org.apache.camel.processor.TransformProcessor
 
getId() - Method in class org.apache.camel.processor.TryProcessor
 
getId() - Method in class org.apache.camel.processor.WireTapProcessor
 
getIdempotentRepository() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getIgnoreEmptyLines() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getIgnoreExtraColumns() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getIgnoreFirstRecord() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getIgnoreHeaderCase() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getIgnoreInvalidCorrelationKeys() - Method in class org.apache.camel.model.AggregateDefinition
 
getIgnoreInvalidEndpoint() - Method in class org.apache.camel.model.EnrichDefinition
 
getIgnoreInvalidEndpoint() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getIgnoreInvalidEndpoint() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getIgnoreInvalidEndpoints() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getIgnoreInvalidEndpoints() - Method in class org.apache.camel.model.RecipientListDefinition
 
getIgnoreInvalidEndpoints() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getIgnoreInvalidExchanges() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getIgnoreInvalidExchanges() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getIgnoreInvalidRecords() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getIgnoreJAXBElement() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getIgnoreLeadingWhitespaces() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getIgnoreSurroundingSpaces() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getIgnoreTrailingWhitespaces() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getIgnoreUnexpectedRecords() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getIgnoreUnidentifiedRecords() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getImageType() - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
 
getImplicitCollections() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getInBody(Exchange) - Method in class org.apache.camel.component.test.TestEndpoint
This method allows us to convert or coerce the expected message body into some other type
getInclude() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getInclude() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getIncludeHeaders() - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
getIncludeNonSingletons() - Method in class org.apache.camel.model.ContextScanDefinition
 
getIncludes() - Method in class org.apache.camel.model.ContextScanDefinition
 
getIncludes() - Method in class org.apache.camel.model.PackageScanDefinition
 
getIncludeTokens() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getIndex() - Method in exception org.apache.camel.component.bean.ParameterBindingException
 
getIndex() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getIndex() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
Index where the parsing error occurred
getIndex() - Method in exception org.apache.camel.language.simple.types.SimpleParserException
Index where the parsing error occurred
getIndex() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getIndex() - Method in class org.apache.camel.model.ProcessorDefinition
Gets the unique index number for when this ProcessorDefinition was created by its constructor.
getIndex() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getInflightRepository() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getInformation() - Method in class org.apache.camel.main.MainSupport.Option
 
getInformation() - Method in class org.apache.camel.main.MainSupport.ParameterOption
 
getInHeader() - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
getInheritNamespaceTagName() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getInheritNamespaceTagName() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getInitialDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getInitialDelay() - Method in class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
getInitialDelay() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getInitialDelay() - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
getInitialDelay() - Method in class org.apache.camel.impl.SupervisingRouteController
 
getInitialization() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getInitialProperties() - Method in class org.apache.camel.main.MainSupport
 
getInitVectorRef() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getInjectionBeanValue(Class<?>, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getInjectionPropertyValue(Class<?>, String, String, String, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getInjectionValue(Class<?>, String, String, String, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Creates the object to be injected for an EndpointInject or Produce injection point
getInjectionValue(Class<?>, String, String, String, Object, String, boolean) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Creates the object to be injected for an EndpointInject or Produce injection point
getInjector() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getInline() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getInProgressCompleteExchanges() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getInput() - Method in class org.apache.camel.model.RouteDefinition
 
getInputs() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
getInputs() - Method in class org.apache.camel.impl.RouteService
Gets the inputs to the routes.
getInputType() - Method in class org.apache.camel.model.RouteDefinition
 
getInQuery() - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
getInstance() - Static method in class org.apache.camel.main.Main
Returns the currently executing main
getInstance() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getInstanceClass() - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
 
getInstanceClass() - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
 
getInstanceClassName() - Method in class org.apache.camel.model.dataformat.AvroDataFormat
 
getIntegrity() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getIntercepted() - Method in class org.apache.camel.model.InterceptDefinition
 
getInterceptedProcessor(int) - Method in class org.apache.camel.model.InterceptDefinition
 
getInterceptFroms() - Method in class org.apache.camel.model.RoutesDefinition
 
getIntercepts() - Method in class org.apache.camel.model.RoutesDefinition
 
getInterceptSendTos() - Method in class org.apache.camel.model.RoutesDefinition
 
getInterceptStrategies() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getInterceptStrategies() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getInterceptStrategies() - Method in class org.apache.camel.model.ProcessorDefinition
 
getInterceptStrategies() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getJaxbProviderProperties() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getJsonDataFormat() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getJsonView() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getJsonView() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getKeepAliveTime() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getKeepAliveTime() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getKeepAliveTime() - Method in class org.apache.camel.model.ThreadsDefinition
 
getKey() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getKey() - Method in class org.apache.camel.model.GlobalOptionDefinition
 
getKey() - Method in class org.apache.camel.model.PropertyDefinition
 
getKey() - Method in class org.apache.camel.model.rest.RestPropertyDefinition
 
getKey() - Method in class org.apache.camel.model.rest.RestSecurityDefinition
 
getKey() - Method in class org.apache.camel.model.rest.SecurityDefinition
 
getKey() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getKeyCipherAlgorithm() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getKeyFileName() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getKeyOrTrustStoreParameters() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getKeyOrTrustStoreParametersRef() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getKeyPassword() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getKeyRef() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getKeys() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
getKeyUserid() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getLabel() - Method in class org.apache.camel.model.AggregateDefinition
 
getLabel() - Method in class org.apache.camel.model.BeanDefinition
 
getLabel() - Method in class org.apache.camel.model.CatchDefinition
 
getLabel() - Method in class org.apache.camel.model.ChoiceDefinition
 
getLabel() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getLabel() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getLabel() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getLabel() - Method in class org.apache.camel.model.DelayDefinition
 
getLabel() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getLabel() - Method in class org.apache.camel.model.EnrichDefinition
 
getLabel() - Method in class org.apache.camel.model.ExpressionNode
 
getLabel() - Method in class org.apache.camel.model.FilterDefinition
 
getLabel() - Method in class org.apache.camel.model.FinallyDefinition
 
getLabel() - Method in class org.apache.camel.model.FromDefinition
 
getLabel() - Method in class org.apache.camel.model.HystrixDefinition
 
getLabel() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getLabel() - Method in class org.apache.camel.model.InOnlyDefinition
 
getLabel() - Method in class org.apache.camel.model.InOutDefinition
 
getLabel() - Method in class org.apache.camel.model.InputTypeDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getLabel(List<ExpressionDefinition>) - Static method in class org.apache.camel.model.language.ExpressionDefinition
 
getLabel() - Method in class org.apache.camel.model.language.ExpressionDefinition
Returns some descriptive text to describe this node
getLabel() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getLabel() - Method in class org.apache.camel.model.LogDefinition
 
getLabel() - Method in class org.apache.camel.model.LoopDefinition
 
getLabel() - Method in class org.apache.camel.model.MarshalDefinition
 
getLabel() - Method in class org.apache.camel.model.MulticastDefinition
 
getLabel() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getLabel() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getLabel() - Method in class org.apache.camel.model.OnFallbackDefinition
 
getLabel() - Method in class org.apache.camel.model.OtherwiseDefinition
 
getLabel() - Method in class org.apache.camel.model.OutputTypeDefinition
 
getLabel() - Method in class org.apache.camel.model.PipelineDefinition
 
getLabel() - Method in class org.apache.camel.model.PolicyDefinition
 
getLabel() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getLabel() - Method in class org.apache.camel.model.ProcessDefinition
 
getLabel() - Method in class org.apache.camel.model.ProcessorDefinition
Returns a label to describe this node such as the expression if some kind of expression node
getLabel() - Method in class org.apache.camel.model.RecipientListDefinition
 
getLabel() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
getLabel() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
getLabel() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
getLabel() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
getLabel() - Method in class org.apache.camel.model.ResequenceDefinition
 
getLabel() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getLabel() - Method in class org.apache.camel.model.rest.RestDefinition
 
getLabel() - Method in class org.apache.camel.model.rest.RestsDefinition
 
getLabel() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getLabel() - Method in class org.apache.camel.model.RollbackDefinition
 
getLabel() - Method in class org.apache.camel.model.RoutesDefinition
 
getLabel() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getLabel() - Method in class org.apache.camel.model.SagaDefinition
 
getLabel() - Method in class org.apache.camel.model.SamplingDefinition
 
getLabel() - Method in class org.apache.camel.model.ScriptDefinition
 
getLabel() - Method in class org.apache.camel.model.SendDefinition
 
getLabel() - Method in class org.apache.camel.model.SetBodyDefinition
 
getLabel() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getLabel() - Method in class org.apache.camel.model.SetFaultBodyDefinition
 
getLabel() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getLabel() - Method in class org.apache.camel.model.SetPropertyDefinition
 
getLabel() - Method in class org.apache.camel.model.SortDefinition
 
getLabel() - Method in class org.apache.camel.model.SplitDefinition
 
getLabel() - Method in class org.apache.camel.model.StepDefinition
 
getLabel() - Method in class org.apache.camel.model.StopDefinition
 
getLabel() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getLabel() - Method in class org.apache.camel.model.ThreadsDefinition
 
getLabel() - Method in class org.apache.camel.model.ThrottleDefinition
 
getLabel() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getLabel() - Method in class org.apache.camel.model.TransactedDefinition
 
getLabel() - Method in class org.apache.camel.model.TransformDefinition
 
getLabel() - Method in class org.apache.camel.model.TryDefinition
 
getLabel() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getLabel() - Method in class org.apache.camel.model.ValidateDefinition
 
getLabel() - Method in class org.apache.camel.model.WhenDefinition
 
getLabel() - Method in class org.apache.camel.model.WireTapDefinition
 
getLang() - Method in class org.apache.camel.model.DescriptionDefinition
 
getLanguage() - Method in class org.apache.camel.model.language.ConstantExpression
 
getLanguage() - Method in class org.apache.camel.model.language.ExchangePropertyExpression
 
getLanguage() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getLanguage() - Method in class org.apache.camel.model.language.GroovyExpression
 
getLanguage() - Method in class org.apache.camel.model.language.HeaderExpression
 
getLanguage() - Method in class org.apache.camel.model.language.Hl7TerserExpression
 
getLanguage() - Method in class org.apache.camel.model.language.JavaScriptExpression
Deprecated.
 
getLanguage() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getLanguage() - Method in class org.apache.camel.model.language.LanguageExpression
 
getLanguage() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getLanguage() - Method in class org.apache.camel.model.language.MvelExpression
 
getLanguage() - Method in class org.apache.camel.model.language.OgnlExpression
 
getLanguage() - Method in class org.apache.camel.model.language.RefExpression
 
getLanguage() - Method in class org.apache.camel.model.language.SimpleExpression
 
getLanguage() - Method in class org.apache.camel.model.language.SpELExpression
 
getLanguage() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getLanguage() - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
getLanguage() - Method in class org.apache.camel.model.language.XPathExpression
 
getLanguage() - Method in class org.apache.camel.model.language.XQueryExpression
 
getLanguageNames() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getLanguageParameterJsonSchema(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getLanguageResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
getLastError() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getLastGoodIndex() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getLazyLoad() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getLazyLoad() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getLeft() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
getLeft() - Method in class org.apache.camel.component.mock.TimeClause
 
getLength() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getLength() - Method in class org.apache.camel.model.dataformat.UniVocityHeader
 
getLibrary() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getLibrary() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getLifecycleStrategies() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getLimit() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
getLimit() - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
getLineLength() - Method in class org.apache.camel.model.dataformat.Base64DataFormat
 
getLineSeparator() - Method in class org.apache.camel.model.dataformat.Base64DataFormat
 
getLineSeparator() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getList() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasList
 
getList() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterList
 
getList() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionList
 
getList() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldList
 
getLoadBalancer() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getLoadBalancer() - Method in class org.apache.camel.model.LoadBalancerDefinition
 
getLoadBalancerConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getLoadBalancerConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getLoadBalancerRef() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getLoadBalancerRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getLoadBalancerType() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getLoadBalancerTypeName() - Method in class org.apache.camel.model.LoadBalancerDefinition
 
getLocale() - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
getLog() - Method in class org.apache.camel.impl.DefaultComponentResolver
 
getLog() - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
getLogContinued() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogExhausted() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogExhaustedMessageBody() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogExhaustedMessageBody() - Method in class org.apache.camel.processor.RedeliveryPolicy
Whether the option logExhaustedMessageBody has been configured or not
getLogExhaustedMessageHistory() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.RedeliveryPolicy
Whether the option logExhaustedMessageHistory has been configured or not
getLogFormatter() - Method in class org.apache.camel.processor.LogProcessor
 
getLogger() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getLogger() - Method in class org.apache.camel.model.LogDefinition
 
getLogger() - Method in class org.apache.camel.processor.LogProcessor
 
getLogger() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getLoggerRef() - Method in class org.apache.camel.model.LogDefinition
 
getLoggingLevel() - Method in class org.apache.camel.model.LogDefinition
 
getLoggingLevel() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getLogHandled() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogListeners() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getLogMask() - Method in class org.apache.camel.model.RouteDefinition
Whether security mask for Logging is enabled on this route.
getLogName() - Method in class org.apache.camel.model.LogDefinition
 
getLogNamespaces() - Method in class org.apache.camel.model.language.XPathExpression
 
getLogNewException() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogRetryAttempted() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogRetryStackTrace() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLogStackTrace() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getLookup() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getMacAlgorithm() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getManagementAgent() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getManagementInterceptStrategy() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getManagementMBeanAssembler() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getManagementName() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getManagementNameStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getManagementObjectNameStrategy() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getManagementObjectStrategy() - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
getManagementStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getMandatoryDefaultEndpoint() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getMapping() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getMarker() - Method in class org.apache.camel.model.LogDefinition
 
getMarkRollbackOnly() - Method in class org.apache.camel.model.RollbackDefinition
 
getMarkRollbackOnlyLast() - Method in class org.apache.camel.model.RollbackDefinition
 
getMarshallerFactoryRef() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Returns the CsvMarshallerFactory reference.
getMasterUrl() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getMaxCacheSize() - Method in class org.apache.camel.impl.ServicePool
 
getMaxFileStoreSize() - Method in class org.apache.camel.impl.FileStateRepository
 
getMaximumCacheSize() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getMaximumFailoverAttempts() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getMaximumFailoverAttempts() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getMaximumNumberOfOutputs() - Method in class org.apache.camel.model.LoadBalancerDefinition
Maximum number of outputs, as some load balancers only support 1 processor
getMaximumRedeliveries() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getMaximumRedeliveries() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getMaximumRequestsPerPeriodExpression() - Method in class org.apache.camel.processor.Throttler
 
getMaximumRetries() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
getMaximumRetries() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMaximumRetryDelay() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
getMaximumRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMaximumSize() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMaxMessages() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
getMaxPoolSize() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getMaxPoolSize() - Method in class org.apache.camel.model.ThreadsDefinition
 
getMaxQueueSize() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMaxQueueSize() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getMaxQueueSize() - Method in class org.apache.camel.model.ThreadsDefinition
 
getMaxSeconds() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
getMaxSeconds() - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
 
getMessage() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
getMessage() - Method in class org.apache.camel.model.LogDefinition
 
getMessage() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
getMessage() - Method in class org.apache.camel.model.RollbackDefinition
 
getMessage() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getMessage() - Method in class org.apache.camel.processor.RollbackProcessor
 
getMessage() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getMessageAsXml() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getMessageFrequency() - Method in class org.apache.camel.model.SamplingDefinition
 
getMessageFrequency() - Method in class org.apache.camel.processor.SamplingThrottler
 
getMessageHistory() - Method in class org.apache.camel.model.RouteDefinition
Whether message history is enabled on this route.
getMessageHistoryFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getMessageIdExpression() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getMessageIdRepository() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getMessageIdRepositoryRef() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getMetadata() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getMetadata() - Method in class org.apache.camel.impl.cloud.DefaultServiceHealth
 
getMethod() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
getMethod() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getMethod() - Method in class org.apache.camel.component.bean.BeanInvocation
 
getMethod() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getMethod() - Method in class org.apache.camel.component.bean.MethodBean
 
getMethod() - Method in class org.apache.camel.component.bean.MethodInfo
 
getMethod() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getMethod() - Method in exception org.apache.camel.component.bean.ParameterBindingException
 
getMethod() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getMethod() - Method in class org.apache.camel.model.BeanDefinition
 
getMethod() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getMethod() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getMethodInfo(Method) - Method in class org.apache.camel.component.bean.BeanInfo
Returns the MethodInfo for the given method if it exists or null if there is no metadata available for the given method
getMethodInfo(Method) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
getMethodName() - Method in exception org.apache.camel.component.bean.MethodNotFoundException
 
getMethodName() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
getMethods() - Method in exception org.apache.camel.component.bean.AmbiguousMethodCallException
The ambiguous methods for which a single method could not be chosen
getMethods() - Method in class org.apache.camel.component.bean.BeanInfo
Gets the list of methods sorted by A..Z method name.
getMetricsHealthSnapshotIntervalInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingPercentileBucketSize() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingPercentileEnabled() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingPercentileWindowBuckets() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingPercentileWindowInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingStatisticalWindowBuckets() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMetricsRollingStatisticalWindowInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getMgfAlgorithm() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getMinRate() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getMisses() - Method in class org.apache.camel.impl.DefaultConsumerCache
Gets the cache misses statistic

Will return -1 if it cannot determine this if a custom cache was used.

getMisses() - Method in class org.apache.camel.impl.DefaultProducerCache
Gets the cache misses statistic

Will return -1 if it cannot determine this if a custom cache was used.

getMisses() - Method in class org.apache.camel.impl.ServicePool
 
getMode() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
getMode() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getMode() - Method in class org.apache.camel.model.language.XMLTokenizerExpression
 
getMode() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getModelJAXBContextFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getModuleClassNames() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getModuleClassNames() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getModuleRefs() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getModuleRefs() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getMultipartSubType() - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
getMultipartWithoutAttachment() - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
getMustBeJAXBElement() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getName() - Method in class org.apache.camel.component.bean.MethodBean
 
getName() - Method in class org.apache.camel.component.bean.RegistryBean
 
getName() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getName() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getName() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getName() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getName() - Method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
getName() - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
 
getName() - Method in class org.apache.camel.impl.ExplicitCamelContextNameStrategy
 
getName() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getName() - Method in class org.apache.camel.model.dataformat.UniVocityHeader
 
getName() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
getName() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getName() - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
getName() - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
getNamePattern() - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
 
getNamespace() - Method in class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
getNamespace() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getNamespace() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getNamespace() - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
getNamespace() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getNamespaceContext() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the namespace context, can be null if no custom context has been assigned.
getNamespacePrefixRef() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getNamespacePrefixRef() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getNamespaces() - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getNamespaces() - Method in class org.apache.camel.builder.xml.Namespaces
 
getNamespaces() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getNamespaces() - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
getNamespaces() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getNamespaces() - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
getNamespaceURI(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getNameStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getNewExchangeExpression() - Method in class org.apache.camel.model.WireTapDefinition
 
getNewExchangeExpression() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNewExchangeProcessor() - Method in class org.apache.camel.model.WireTapDefinition
 
getNewExchangeProcessorRef() - Method in class org.apache.camel.model.WireTapDefinition
 
getNewExchangeProcessors() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNextCounter() - Static method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.ExplicitCamelContextNameStrategy
 
getNextProcessor() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getNodeCounter(String) - Static method in class org.apache.camel.impl.DefaultNodeIdFactory
Returns the counter for the given node key, lazily creating one if necessary
getNodeIdFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getNodes() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getNoNamespaceSchemaLocation() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getNormalizedLineSeparator() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getNotFilteredCount() - Method in class org.apache.camel.processor.ChoiceProcessor
Gets the number of Exchanges that did not match any predicate and are routed using otherwise
getNullString() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getNullStringDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getNullValue() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getNumber() - Method in class org.apache.camel.component.mock.Time
 
getNumberOfHashGroups() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getNumberOfRecordsToRead() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getOauthToken() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getObjectFactory() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getObjectMapper() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getObjectModel() - Method in class org.apache.camel.model.language.XPathExpression
 
getObjectModelUri() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getObjectModelUri() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
getOmitFields() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getOmitXmlDeclaration() - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
getOnCompleteOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnCompletion(String) - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnCompletions() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnCompletions() - Method in class org.apache.camel.model.RoutesDefinition
 
getOnExceptionOccurred() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getOnExceptionOccurred() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnExceptionOccurredRef() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnExceptions() - Method in class org.apache.camel.model.RoutesDefinition
 
getOnFailureOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnFallback() - Method in class org.apache.camel.model.HystrixDefinition
 
getOnPrepare() - Method in class org.apache.camel.model.MulticastDefinition
 
getOnPrepare() - Method in class org.apache.camel.model.RecipientListDefinition
 
getOnPrepare() - Method in class org.apache.camel.model.SplitDefinition
 
getOnPrepare() - Method in class org.apache.camel.model.WireTapDefinition
 
getOnPrepare() - Method in class org.apache.camel.processor.RecipientList
 
getOnPrepare() - Method in class org.apache.camel.processor.WireTapProcessor
 
getOnPrepareFailure() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getOnPrepareRef() - Method in class org.apache.camel.model.MulticastDefinition
 
getOnPrepareRef() - Method in class org.apache.camel.model.RecipientListDefinition
 
getOnPrepareRef() - Method in class org.apache.camel.model.SplitDefinition
 
getOnPrepareRef() - Method in class org.apache.camel.model.WireTapDefinition
 
getOnRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getOnRedelivery() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnRedeliveryRef() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnWhen() - Method in class org.apache.camel.model.CatchDefinition
 
getOnWhen() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnWhen() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOperation() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getOperation() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getOperationText() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
getOperationText() - Method in class org.apache.camel.component.mock.TimeClause
 
getOperator() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
getOperator() - Method in class org.apache.camel.component.mock.TimeClause
 
getOperator() - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
getOperator() - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
getOperator() - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
getOperatorText(BinaryOperatorType) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
getOperatorText(LogicalOperatorType) - Method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
getOperatorText(UnaryOperatorType) - Method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
getOptimisticLocking() - Method in class org.apache.camel.model.AggregateDefinition
 
getOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOptimisticLockRetryPolicy() - Method in class org.apache.camel.model.AggregateDefinition
 
getOptimisticLockRetryPolicy() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOptimisticLockRetryPolicyDefinition() - Method in class org.apache.camel.model.AggregateDefinition
 
getOptionName() - Method in class org.apache.camel.model.SagaOptionDefinition
 
getOptions() - Method in class org.apache.camel.model.SagaDefinition
 
getOrCreateRedeliveryPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOrder() - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
getOrder() - Method in class org.apache.camel.impl.DeferServiceStartupListener
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessorAdvice.CamelInternalProcessorAdviceWrapper
 
getOriginal() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
getOriginalEndpoint() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
getOriginalInMessage() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getOriginalRoute() - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Gets the original route to be adviced.
getOrLookupCamelContext() - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
Strategy to get the CamelContext to use.
getOtherAttributes() - Method in class org.apache.camel.model.config.ResequencerConfig
 
getOtherAttributes() - Method in class org.apache.camel.model.DataFormatDefinition
 
getOtherAttributes() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getOtherAttributes() - Method in class org.apache.camel.model.LoadBalancerDefinition
 
getOtherAttributes() - Method in interface org.apache.camel.model.OtherAttributesAware
Adds optional attribute to use as property placeholder
getOtherAttributes() - Method in class org.apache.camel.model.ProcessorDefinition
 
getOtherwise() - Method in class org.apache.camel.model.ChoiceDefinition
 
getOtherwise() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getOutBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getOutBodyFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for getting the output message body.
getOutHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for getting the output message header.
getOutput() - Method in class org.apache.camel.processor.ErrorHandlerSupport
Gets the output
getOutput() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getOutput() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Returns the output processor
getOutputs() - Method in class org.apache.camel.model.AggregateDefinition
 
getOutputs() - Method in class org.apache.camel.model.CatchDefinition
 
getOutputs() - Method in class org.apache.camel.model.ChoiceDefinition
 
getOutputs() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getOutputs() - Method in class org.apache.camel.model.ExpressionNode
 
getOutputs() - Method in class org.apache.camel.model.HystrixDefinition
 
getOutputs() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getOutputs() - Method in class org.apache.camel.model.NoOutputDefinition
 
getOutputs() - Method in class org.apache.camel.model.NoOutputExpressionNode
 
getOutputs() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOutputs() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOutputs() - Method in class org.apache.camel.model.OutputDefinition
 
getOutputs() - Method in class org.apache.camel.model.ProcessorDefinition
 
getOutputs() - Method in class org.apache.camel.model.ResequenceDefinition
 
getOutputs() - Method in class org.apache.camel.model.RouteDefinition
 
getOutputs() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getOutputsWithoutCatches() - Method in class org.apache.camel.model.TryDefinition
 
getOutputTransformer() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getOutputType() - Method in class org.apache.camel.model.RouteDefinition
 
getOutType() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getOutType() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getOverrideProperties() - Method in class org.apache.camel.main.MainSupport
 
getOverrideResourceIdWithBundleEntryFullUrl() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getPackages() - Method in class org.apache.camel.impl.DefaultModelJAXBContextFactory
 
getPackages() - Method in class org.apache.camel.model.PackageScanDefinition
 
getPackageScanClassResolver() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getPadding() - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
 
getParallelAggregate() - Method in class org.apache.camel.model.MulticastDefinition
 
getParallelAggregate() - Method in class org.apache.camel.model.RecipientListDefinition
 
getParallelAggregate() - Method in class org.apache.camel.model.SplitDefinition
 
getParallelProcessing() - Method in class org.apache.camel.model.AggregateDefinition
 
getParallelProcessing() - Method in class org.apache.camel.model.MulticastDefinition
 
getParallelProcessing() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getParallelProcessing() - Method in class org.apache.camel.model.RecipientListDefinition
 
getParallelProcessing() - Method in class org.apache.camel.model.SplitDefinition
 
getParameterMappingStrategy() - Method in class org.apache.camel.component.bean.RegistryBean
 
getParameters() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getParameters() - Method in class org.apache.camel.component.bean.MethodInfo
 
getParametersExpression() - Method in class org.apache.camel.component.bean.MethodInfo
 
getParameterType() - Method in exception org.apache.camel.component.bean.ParameterBindingException
 
getParameterTypes() - Method in class org.apache.camel.component.bean.MethodBean
 
getParameterValue() - Method in exception org.apache.camel.component.bean.ParameterBindingException
 
getParams() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getParent() - Method in class org.apache.camel.model.ProcessorDefinition
 
getParser() - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
getParserErrorHandler() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getParserFactoryRef() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getParserOptions() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getPartClass() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getPartNamespace() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getPassPhrase() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getPassPhraseByte() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getPassword() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getPassword() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getPassword() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getPassword() - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
getPassword() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getPath() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
getPath() - Method in class org.apache.camel.model.rest.RestDefinition
 
getPattern() - Method in class org.apache.camel.component.bean.MethodInfo
Returns the ExchangePattern that should be used when invoking this method.
getPattern() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getPattern() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getPattern() - Method in class org.apache.camel.model.InOnlyDefinition
 
getPattern() - Method in class org.apache.camel.model.InOutDefinition
 
getPattern() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
getPattern() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
getPattern() - Method in class org.apache.camel.model.SendDefinition
 
getPattern() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getPattern() - Method in class org.apache.camel.model.ToDefinition
 
getPattern() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getPattern() - Method in class org.apache.camel.model.WireTapDefinition
 
getPattern() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getPattern() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getPattern() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getPattern() - Method in class org.apache.camel.processor.SendProcessor
 
getPatternAnnotation(AnnotatedElement) - Method in class org.apache.camel.component.bean.MethodInfo
Returns the pattern annotation on the given annotated element; either as a direct annotation or on an annotation which is also annotated
getPatternAnnotation(AnnotatedElement, int) - Method in class org.apache.camel.component.bean.MethodInfo
Returns the pattern annotation on the given annotated element; either as a direct annotation or on an annotation which is also annotated
getPendingExchangesSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.WireTapProcessor
 
getPendingInflightExchanges(RouteStartupOrder) - Static method in class org.apache.camel.impl.DefaultShutdownStrategy
Calculates the total number of inflight exchanges for the given route
getPendingRedeliveryCount() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Gets the number of exchanges that are pending for redelivery
getPermissions() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getPermissions() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getPhase() - Method in class org.apache.camel.impl.DefaultRouteError
 
getPolicy() - Method in class org.apache.camel.model.PolicyDefinition
 
getPolicy() - Method in class org.apache.camel.model.TransactedDefinition
 
getPollingConsumerServicePool() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getPool(Endpoint) - Method in class org.apache.camel.impl.ServicePool
 
getPoolSize() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getPoolSize() - Method in class org.apache.camel.model.ThreadsDefinition
 
getPort() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
getPort() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getPortHeader() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getPortName() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getPortProtocol() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getPostProcessorHelper() - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
Strategy to get the CamelPostProcessorHelper
getPredicate() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getPredicate() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getPredicate() - Method in class org.apache.camel.processor.FilterProcessor
 
getPredicate() - Method in class org.apache.camel.processor.LoopProcessor
 
getPreferTypes() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getPrefix(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getPrefixes(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getPreloadSize() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getPreservePathElements() - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
 
getPreservePathElements() - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getProcessor() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
getProcessor() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getProcessor() - Method in interface org.apache.camel.component.bean.BeanHolder
Gets a Processor for this bean, if supported.
getProcessor() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getProcessor() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getProcessor() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
getProcessor() - Method in class org.apache.camel.component.bean.RegistryBean
 
getProcessor(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProcessor(String, Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProcessor() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
getProcessor() - Method in class org.apache.camel.model.ProcessDefinition
 
getProcessor() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getProcessor() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getProcessor() - Method in class org.apache.camel.processor.Resequencer
 
getProcessor() - Method in class org.apache.camel.processor.StreamResequencer
Returns the next processor.
getProcessorDefinition(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProcessorDefinition(String, Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProcessorDefinition(String) - Method in interface org.apache.camel.model.ModelCamelContext
Gets the processor definition from any of the routes which with the given id
getProcessorDefinition(String, Class<T>) - Method in interface org.apache.camel.model.ModelCamelContext
Gets the processor definition from any of the routes which with the given id
getProcessorDefinition() - Method in interface org.apache.camel.model.ModelChannel
Gets the definition of the next processor
getProcessorDefinition() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getProcessorFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProcessors() - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Returns the current processors available to this load balancer
getProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getProcessors() - Method in class org.apache.camel.processor.MulticastProcessor
Returns the producers to multicast to
getProcessors() - Method in class org.apache.camel.processor.Pipeline
 
getProduceDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getProducer() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getProducerApiDoc() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getProducerComponent() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getProducerServicePool() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProduces() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getProduces() - Method in class org.apache.camel.model.rest.RestDefinition
 
getProduces() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getPropagation() - Method in class org.apache.camel.model.SagaDefinition
 
getProperties() - Method in class org.apache.camel.impl.DefaultRoute
 
getProperties() - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getProperties() - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
getProperties() - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
getProperties() - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
getProperties() - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
getPropertiesAsMap(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
getPropertiesAsMap(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
getPropertiesAsMap(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
getPropertiesAsMap(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
getPropertiesAsMap(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
getPropertiesComponent() - Method in class org.apache.camel.impl.AbstractCamelContext
Gets the properties component in use, eventually creating it.
getPropertiesComponent(boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getPropertiesFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for getting the exchange properties.
getPropertyName() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
getPropertyName() - Method in class org.apache.camel.model.SetPropertyDefinition
 
getPropertyName() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getPropertyName() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getPropertyPlaceholderLocations() - Method in class org.apache.camel.main.MainSupport
 
getPropertyPrefixToken() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getPropertySuffixToken() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getProto() - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
 
getProvider() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getQueueSizeRejectionThreshold() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getQuote() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getQuote() - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
getQuoteAllFields() - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
getQuoteDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getQuoteEscape() - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
getQuoteMode() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getRandomBackOff() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
getRandomNumberGenerator() - Static method in class org.apache.camel.processor.RedeliveryPolicy
 
getRatios() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
getReadTimeoutMillis() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getReceivedCounter() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getReceivedCounter() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getReceivedExchanges() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRecipientKeyAlias() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getReconnectBaseSleepTime() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getReconnectMaxRetries() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getReconnectMaxSleepTime() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getRecordConverterRef() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getRecordEndsOnNewline() - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
 
getRecordSeparator() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getRecordSeparatorDisabled() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getRedeliveryDelay() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRedeliveryDelay() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRedeliveryPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getRedeliveryPolicy() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getRedeliveryPolicyRef() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRedeliveryPolicyType() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRef() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
getRef() - Method in class org.apache.camel.model.BeanDefinition
 
getRef() - Method in class org.apache.camel.model.dataformat.CustomDataFormat
Reference to the custom DataFormat to lookup from the Camel registry.
getRef() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getRef() - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
 
getRef() - Method in class org.apache.camel.model.PolicyDefinition
 
getRef() - Method in class org.apache.camel.model.ProcessDefinition
 
getRef() - Method in class org.apache.camel.model.RestContextRefDefinition
 
getRef() - Method in class org.apache.camel.model.RouteBuilderDefinition
 
getRef() - Method in class org.apache.camel.model.RouteContextRefDefinition
 
getRef() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getRef() - Method in class org.apache.camel.model.TransactedDefinition
 
getRef() - Method in class org.apache.camel.model.transformer.CustomTransformerDefinition
 
getRef() - Method in class org.apache.camel.model.transformer.DataFormatTransformerDefinition
 
getRef() - Method in class org.apache.camel.model.transformer.EndpointTransformerDefinition
 
getRef() - Method in class org.apache.camel.model.validator.CustomValidatorDefinition
 
getRef() - Method in class org.apache.camel.model.validator.EndpointValidatorDefinition
 
getRegex() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getRegistry() - Method in class org.apache.camel.component.bean.RegistryBean
 
getRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRegistry(Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRejectedExecutionHandler() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getRejectedPolicy() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getRejectedPolicy() - Method in class org.apache.camel.model.ThreadsDefinition
 
getRejectedPolicy() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getRejectExecution() - Method in class org.apache.camel.model.ThrottleDefinition
 
getRejectOld() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getRejectOld() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
getReloadCounter() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
getReloadStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getReloadStrategy() - Method in class org.apache.camel.main.MainSupport
 
getRemoveOnFailure() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getReportCount() - Method in interface org.apache.camel.component.dataset.DataSet
Returns the number of messages which should be received before reporting on the progress of the test
getReportCount() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getReporter() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRepresenter() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getRequest() - Method in class org.apache.camel.model.dataformat.XmlRpcDataFormat
 
getRequestLogEnabled() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getRequired() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getRequiredBody() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getRequiredHeaders() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getRequiredQueryParameters() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getResequencerConfig() - Method in class org.apache.camel.model.ResequenceDefinition
 
getResolver() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getResourcePath() - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
Strategy to get the resources by the given classloader.
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.WebSpherePackageScanClassResolver
Overloaded to handle specific problem with getting resources on the IBM WebSphere platform.
getResponseModel() - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
getResponseMsgs() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getRest() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getRestBindingDefinition() - Method in class org.apache.camel.model.RouteDefinition
 
getRestCollection() - Method in class org.apache.camel.builder.RouteBuilder
 
getRestConfiguration() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRestConfiguration(String, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRestConfigurations() - Method in class org.apache.camel.builder.RouteBuilder
 
getRestConfigurations() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRestDefinition() - Method in class org.apache.camel.model.RouteDefinition
 
getRestDefinitions() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRestDefinitions() - Method in interface org.apache.camel.model.ModelCamelContext
Returns a list of the current REST definitions
getRestRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRests() - Method in interface org.apache.camel.model.rest.RestContainer
Returns the RESTs
getRests() - Method in class org.apache.camel.model.rest.RestsDefinition
 
getResultQName() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getResultType() - Method in class org.apache.camel.builder.SimpleBuilder
 
getResultType() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getResultType(Annotation) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
getResultType() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
getResultType() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getResultType() - Method in class org.apache.camel.model.language.SimpleExpression
 
getResultType() - Method in class org.apache.camel.model.language.XPathExpression
 
getResultType() - Method in class org.apache.camel.model.language.XQueryExpression
 
getResultTypeName() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getResultTypeName() - Method in class org.apache.camel.model.language.SimpleExpression
 
getResultTypeName() - Method in class org.apache.camel.model.language.XPathExpression
 
getResultWaitTime() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRetryAttemptedLogInterval() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRetryAttemptedLogInterval() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRetryDelay() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
getRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getRetryWhile() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getRetryWhile() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRetryWhilePolicy(CamelContext) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getRetryWhilePolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRetryWhileRef() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getReverse() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getRight() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
getRight() - Method in class org.apache.camel.component.mock.TimeClause
 
getRoundRobin() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getRoundRobin() - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
 
getRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRoute() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getRoute() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
getRoute(NamedNode) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Gets the route definition the given node belongs to.
getRoute() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getRouteBuilderClasses() - Method in class org.apache.camel.main.MainSupport
 
getRouteBuilders() - Method in class org.apache.camel.main.MainSupport
 
getRouteCollection() - Method in class org.apache.camel.builder.RouteBuilder
 
getRouteContext() - Method in class org.apache.camel.impl.DefaultRoute
 
getRouteContext() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getRouteContext() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
getRouteContexts() - Method in class org.apache.camel.impl.RouteService
 
getRouteController() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteController() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getRouteDefinition(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteDefinition() - Method in class org.apache.camel.impl.RouteService
 
getRouteDefinition(String) - Method in interface org.apache.camel.model.ModelCamelContext
Gets the route definition with the given id
getRouteDefinitions() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteDefinitions() - Method in class org.apache.camel.main.MainSupport
 
getRouteDefinitions() - Method in interface org.apache.camel.model.ModelCamelContext
Returns a list of the current route definitions
getRouteId(RouteContext) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
getRouteId(NamedNode) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Gets the route id the given node belongs to.
getRouteId() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getRouteId() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
getRouteId() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getRouteMessage(String) - Static method in class org.apache.camel.model.RouteDefinitionHelper
 
getRoutePolicies() - Method in class org.apache.camel.model.RouteDefinition
 
getRoutePolicyFactories() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRoutePolicyList() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getRoutePolicyRef() - Method in class org.apache.camel.model.RouteDefinition
Reference to custom RoutePolicy to use by the route.
getRouteProperties() - Method in class org.apache.camel.model.RouteDefinition
 
getRoutes() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRoutes() - Method in class org.apache.camel.impl.RouteService
 
getRoutes() - Method in interface org.apache.camel.model.RouteContainer
Returns the routes
getRoutes() - Method in class org.apache.camel.model.RoutesDefinition
 
getRoutesConfiguration() - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
getRouteScoped() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getRouteScoped() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRouteService() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
getRouteServices() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteStartupOrder() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteStatus(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRouteStatus(String) - Method in class org.apache.camel.impl.DefaultRouteController
 
getRuntimeEndpointRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getRuntimeWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getSagaService() - Method in class org.apache.camel.model.SagaDefinition
 
getSagaService() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getSamplePeriod() - Method in class org.apache.camel.model.SamplingDefinition
 
getSamplePeriod() - Method in class org.apache.camel.processor.SamplingThrottler
 
getSaxon() - Method in class org.apache.camel.model.language.XPathExpression
 
getSchema() - Method in class org.apache.camel.model.dataformat.AvroDataFormat
 
getSchema() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getSchema() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getSchemaLocation() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getSchemaSeverityLevel() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getScheme() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getScheme() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getScheme() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getScheme() - Method in class org.apache.camel.model.transformer.TransformerDefinition
 
getScopes() - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
getScopes() - Method in class org.apache.camel.model.rest.SecurityDefinition
 
getSecureTag() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getSecureTagContents() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getSecurity() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getSecurityDefinitions() - Method in class org.apache.camel.model.rest.RestDefinition
 
getSecurityDefinitions() - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
getSequenceSender() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the sequence sender.
getServerBaseUrl() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getServers() - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilterFactory
 
getServers() - Method in class org.apache.camel.impl.cloud.StaticServiceDiscoveryFactory
 
getServers() - Method in class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
 
getServers() - Method in class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
 
getServiceCallConfiguration(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
getServiceCallConfiguration(String) - Method in interface org.apache.camel.model.ModelCamelContext
Gets the service call configuration by the given name.
getServiceChooser() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
getServiceChooser() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceChooser() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceChooserRef() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceChooserRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceDiscovery() - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
getServiceDiscovery() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
getServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceDiscoveryConfiguration() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
getServiceDiscoveryConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceDiscoveryConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceDiscoveryConfigurations() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
getServiceDiscoveryList() - Method in class org.apache.camel.impl.cloud.CombinedServiceDiscoveryFactory
 
getServiceDiscoveryRef() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceDiscoveryRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceFilter() - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
getServiceFilter() - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
 
getServiceFilter() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceFilter() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceFilterConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceFilterConfiguration() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServiceFilterConfigurations() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
getServiceFilterList() - Method in class org.apache.camel.impl.cloud.CombinedServiceFilterFactory
 
getServiceFilterRef() - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
 
getServiceFilterRef() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getServiceFilterRef() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getServicePath() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getServices(String) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
getServices(String) - Method in class org.apache.camel.impl.cloud.CombinedServiceDiscovery
 
getServices(String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
getServices(String) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
getServices() - Method in class org.apache.camel.impl.DefaultRoute
 
getServices() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
getSessionTimeout() - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
getShareUnitOfWork() - Method in class org.apache.camel.model.EnrichDefinition
 
getShareUnitOfWork() - Method in class org.apache.camel.model.MulticastDefinition
 
getShareUnitOfWork() - Method in class org.apache.camel.model.RecipientListDefinition
 
getShareUnitOfWork() - Method in class org.apache.camel.model.SplitDefinition
 
getShortMessage() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
Gets a short error message.
getShortName() - Method in class org.apache.camel.model.AggregateDefinition
 
getShortName() - Method in class org.apache.camel.model.BeanDefinition
 
getShortName() - Method in class org.apache.camel.model.CatchDefinition
 
getShortName() - Method in class org.apache.camel.model.ChoiceDefinition
 
getShortName() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
getShortName() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getShortName() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getShortName() - Method in class org.apache.camel.model.DataFormatDefinition
 
getShortName() - Method in class org.apache.camel.model.DelayDefinition
 
getShortName() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getShortName() - Method in class org.apache.camel.model.EnrichDefinition
 
getShortName() - Method in class org.apache.camel.model.FilterDefinition
 
getShortName() - Method in class org.apache.camel.model.FinallyDefinition
 
getShortName() - Method in class org.apache.camel.model.FromDefinition
 
getShortName() - Method in class org.apache.camel.model.HystrixDefinition
 
getShortName() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getShortName() - Method in class org.apache.camel.model.InOnlyDefinition
 
getShortName() - Method in class org.apache.camel.model.InOutDefinition
 
getShortName() - Method in class org.apache.camel.model.InputTypeDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getShortName() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getShortName() - Method in class org.apache.camel.model.LogDefinition
 
getShortName() - Method in class org.apache.camel.model.LoopDefinition
 
getShortName() - Method in class org.apache.camel.model.MarshalDefinition
 
getShortName() - Method in class org.apache.camel.model.MulticastDefinition
 
getShortName() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getShortName() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getShortName() - Method in class org.apache.camel.model.OnFallbackDefinition
 
getShortName() - Method in class org.apache.camel.model.OtherwiseDefinition
 
getShortName() - Method in class org.apache.camel.model.OutputDefinition
 
getShortName() - Method in class org.apache.camel.model.OutputTypeDefinition
 
getShortName() - Method in class org.apache.camel.model.PipelineDefinition
 
getShortName() - Method in class org.apache.camel.model.PolicyDefinition
 
getShortName() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getShortName() - Method in class org.apache.camel.model.ProcessDefinition
 
getShortName() - Method in class org.apache.camel.model.RecipientListDefinition
 
getShortName() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
getShortName() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
getShortName() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
getShortName() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
getShortName() - Method in class org.apache.camel.model.ResequenceDefinition
 
getShortName() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getShortName() - Method in class org.apache.camel.model.rest.RestDefinition
 
getShortName() - Method in class org.apache.camel.model.rest.RestsDefinition
 
getShortName() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getShortName() - Method in class org.apache.camel.model.RollbackDefinition
 
getShortName() - Method in class org.apache.camel.model.RouteDefinition
 
getShortName() - Method in class org.apache.camel.model.RoutesDefinition
 
getShortName() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getShortName() - Method in class org.apache.camel.model.SamplingDefinition
 
getShortName() - Method in class org.apache.camel.model.ScriptDefinition
 
getShortName() - Method in class org.apache.camel.model.SetBodyDefinition
 
getShortName() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getShortName() - Method in class org.apache.camel.model.SetFaultBodyDefinition
 
getShortName() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getShortName() - Method in class org.apache.camel.model.SetPropertyDefinition
 
getShortName() - Method in class org.apache.camel.model.SortDefinition
 
getShortName() - Method in class org.apache.camel.model.SplitDefinition
 
getShortName() - Method in class org.apache.camel.model.StepDefinition
 
getShortName() - Method in class org.apache.camel.model.StopDefinition
 
getShortName() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getShortName() - Method in class org.apache.camel.model.ThreadsDefinition
 
getShortName() - Method in class org.apache.camel.model.ThrottleDefinition
 
getShortName() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getShortName() - Method in class org.apache.camel.model.ToDefinition
 
getShortName() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getShortName() - Method in class org.apache.camel.model.TransactedDefinition
 
getShortName() - Method in class org.apache.camel.model.TransformDefinition
 
getShortName() - Method in class org.apache.camel.model.TryDefinition
 
getShortName() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getShortName() - Method in class org.apache.camel.model.ValidateDefinition
 
getShortName() - Method in class org.apache.camel.model.WhenDefinition
 
getShortName() - Method in class org.apache.camel.model.WhenSkipSendToEndpointDefinition
 
getShortName() - Method in class org.apache.camel.model.WireTapDefinition
 
getShouldAppendHMAC() - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
 
getShutdownAwaitTermination() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
getShutdownRoute() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getShutdownRoute() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getShutdownRoute() - Method in class org.apache.camel.model.RouteDefinition
 
getShutdownRunningTask() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getShutdownRunningTask() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getShutdownRunningTask() - Method in class org.apache.camel.model.RouteDefinition
To control how to shutdown the route.
getShutdownStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getSignatureKeyFileName() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getSignatureKeyRing() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getSignatureKeyUserid() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getSignaturePassword() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getSignatureVerificationOption() - Method in class org.apache.camel.model.dataformat.PGPDataFormat
 
getSimpleFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the XPathFunction for executing simple language as xpath function.
getSize() - Method in interface org.apache.camel.component.dataset.DataSet
Returns the size of the dataset
getSize() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getSkipBindingOnErrorCode() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getSkipBindingOnErrorCode() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getSkipBindingOnErrorCode() - Method in class org.apache.camel.model.rest.RestDefinition
 
getSkipBindingOnErrorCode() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getSkipDuplicate() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getSkipEmptyLines() - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
getSkipFirst() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getSkipHeaderRecord() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getSkipSendToOriginalEndpoint() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getSkipTrailingCharsUntilNewline() - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
 
getSleepForEmptyTest() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getSource() - Method in class org.apache.camel.impl.DefaultConsumerCache
Gets the source which uses this cache
getSource() - Method in class org.apache.camel.impl.DefaultProducerCache
Gets the source which uses this cache
getSourceFile() - Method in class org.apache.camel.component.dataset.FileDataSet
 
getSpoolChiper() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getSpoolDirectory() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getSpoolThreshold() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getSpoolUsedHeapMemoryLimit() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getSpoolUsedHeapMemoryThreshold() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getSSLContextParameters() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getSslContextParameters() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getSslContextParameters() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getStartupOrder() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
getStartupOrder() - Method in class org.apache.camel.model.RouteDefinition
To configure the ordering of the routes being started
getState() - Method in class org.apache.camel.impl.BreakpointSupport
 
getState(String) - Method in class org.apache.camel.impl.FileStateRepository
 
getState(String) - Method in class org.apache.camel.impl.MemoryStateRepository
 
getStaticPart() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getStatistics() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
getStatistics() - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
getStatistics() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
getStatistics() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getStatus(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
Deprecated.
getSticky() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getStickyKey(Object) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
A strategy to create the key for the sticky load balancing map.
getStopOnAggregateException() - Method in class org.apache.camel.model.MulticastDefinition
 
getStopOnAggregateException() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStopOnAggregateException() - Method in class org.apache.camel.model.SplitDefinition
 
getStopOnException() - Method in class org.apache.camel.model.MulticastDefinition
 
getStopOnException() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStopOnException() - Method in class org.apache.camel.model.SplitDefinition
 
getStrategyMethodAllowNull() - Method in class org.apache.camel.model.AggregateDefinition
 
getStrategyMethodAllowNull() - Method in class org.apache.camel.model.MulticastDefinition
 
getStrategyMethodAllowNull() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStrategyMethodAllowNull() - Method in class org.apache.camel.model.SplitDefinition
 
getStrategyMethodName() - Method in class org.apache.camel.model.AggregateDefinition
 
getStrategyMethodName() - Method in class org.apache.camel.model.MulticastDefinition
 
getStrategyMethodName() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStrategyMethodName() - Method in class org.apache.camel.model.SplitDefinition
 
getStrategyRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getStrategyRef() - Method in class org.apache.camel.model.MulticastDefinition
 
getStrategyRef() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStrategyRef() - Method in class org.apache.camel.model.SplitDefinition
 
getStreamCache() - Method in class org.apache.camel.model.RouteDefinition
Whether stream caching is enabled on this route.
getStreamCachingStrategy() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getStreamConfig() - Method in class org.apache.camel.model.ResequenceDefinition
 
getStreaming() - Method in class org.apache.camel.model.MulticastDefinition
 
getStreaming() - Method in class org.apache.camel.model.RecipientListDefinition
 
getStreaming() - Method in class org.apache.camel.model.SplitDefinition
 
getStreamName() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getStripVersionsFromReferences() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
getSubUnitOfWorkCallback() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getSuppressExceptions() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getSuspendedBreakpointNodeIds() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getSuspendedExchange(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
Gets the exchanged suspended at the given breakpoint id or null if there is none at that id.
getTag() - Method in class org.apache.camel.model.rest.RestDefinition
 
getText() - Method in class org.apache.camel.builder.SimpleBuilder
 
getText() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getText() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
getText() - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Gets the text
getText() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getText() - Method in class org.apache.camel.model.DescriptionDefinition
 
getTextQualifier() - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
 
getThis() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getThreadName() - Method in class org.apache.camel.model.ThreadsDefinition
 
getThreadNamePattern() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
getThreadPoolFactory() - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
getThreadPoolKey() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getThreadPoolProfile(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
getThreadPoolRollingNumberStatisticalWindowBuckets() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getThreadPoolRollingNumberStatisticalWindowInMilliseconds() - Method in class org.apache.camel.model.HystrixConfigurationCommon
 
getThreadSafety() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
getThreadSafety() - Method in class org.apache.camel.model.language.XPathExpression
 
getTimeout() - Method in class org.apache.camel.component.test.TestEndpoint
 
getTimeout() - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
getTimeout() - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
getTimeout() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
getTimeout() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
getTimeout() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getTimeout() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getTimeout() - Method in class org.apache.camel.model.MulticastDefinition
 
getTimeout() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getTimeout() - Method in class org.apache.camel.model.RecipientListDefinition
 
getTimeout() - Method in class org.apache.camel.model.SplitDefinition
 
getTimeout() - Method in class org.apache.camel.processor.MulticastProcessor
An optional timeout in millis when using parallel processing
getTimeout() - Method in class org.apache.camel.processor.PollEnricher
 
getTimeout() - Method in class org.apache.camel.processor.RecipientList
 
getTimeout() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns this resequencer's timeout value.
getTimeout() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's timeout.
getTimeoutCheckerExecutorService() - Method in class org.apache.camel.model.AggregateDefinition
 
getTimeoutCheckerExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getTimeoutCheckerExecutorServiceRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Returns the timeout handler that has been registered for notification.
getTimeoutInMilliseconds() - Method in class org.apache.camel.model.SagaDefinition
 
getTimePeriodMillis() - Method in class org.apache.camel.model.ThrottleDefinition
 
getTimePeriodMillis() - Method in class org.apache.camel.processor.Throttler
 
getTimestamp() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getTimeUnit() - Method in class org.apache.camel.component.mock.Time
 
getTimeUnit() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
getTimeUnit() - Method in class org.apache.camel.main.MainSupport
 
getTimeUnit() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
getTimeUnit() - Method in class org.apache.camel.model.ThreadsDefinition
 
getTimezone() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getTo() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getTo() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getToD() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getToken() - Method in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
getToken() - Method in interface org.apache.camel.language.simple.ast.SimpleNode
Gets the token by which this model was based upon
getToken() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getToken() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getTokenUrl() - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
getToNode() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getToOrRoute() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getTotalCompleted() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanges completed and outgoing from the aggregator
getTotalIn() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanges arrived into the aggregator
getToType() - Method in class org.apache.camel.model.transformer.TransformerDefinition
 
getTrace() - Method in class org.apache.camel.model.RouteDefinition
Whether tracing is enabled on this route.
getTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTraceFilter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTraceLabel() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.CatchProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Delayer
 
getTraceLabel() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.FilterProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.FinallyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getTraceLabel() - Method in class org.apache.camel.processor.LogProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.LoopProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.MulticastProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Pipeline
 
getTraceLabel() - Method in class org.apache.camel.processor.RecipientListProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Resequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.RollbackProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RoutingSlip
 
getTraceLabel() - Method in class org.apache.camel.processor.SamplingThrottler
 
getTraceLabel() - Method in class org.apache.camel.processor.ScriptProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SendProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SortProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Splitter
 
getTraceLabel() - Method in class org.apache.camel.processor.StepProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.StreamResequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.Throttler
 
getTraceLabel() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TransformProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TryProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.WireTapProcessor
 
getTracePattern() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTrailingDelimiter() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getTransformerRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getTransformers() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getTransformers() - Method in interface org.apache.camel.model.ModelCamelContext
Gets the transformers that can be referenced in the routes.
getTransformers() - Method in class org.apache.camel.model.transformer.TransformersDefinition
 
getTrim() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getTrim() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getTrustCerts() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getType() - Method in class org.apache.camel.component.bean.BeanInfo
 
getType() - Method in interface org.apache.camel.component.bean.BeanTypeHolder
 
getType() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
getType() - Method in class org.apache.camel.component.bean.MethodBean
 
getType() - Method in class org.apache.camel.component.bean.MethodInfo
 
getType() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getType() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getType() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Gets the type of this token
getType() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getType() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getType() - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
getType() - Method in class org.apache.camel.model.dataformat.YAMLTypeFilterDefinition
 
getType() - Method in class org.apache.camel.model.language.XQueryExpression
 
getType() - Method in class org.apache.camel.model.PolicyDefinition
 
getType() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
getType() - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
getType() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getType() - Method in class org.apache.camel.model.TransactedDefinition
 
getType() - Method in class org.apache.camel.model.validator.ValidatorDefinition
 
getType() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getType() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getTypeClass() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getTypeConverter() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getTypeConverterRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getTypeFilters() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getUid() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getUnitOfWorkFactory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getUnits() - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
getUnits() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
getUnits() - Method in class org.apache.camel.model.SamplingDefinition
 
getUnits() - Method in class org.apache.camel.processor.SamplingThrottler
 
getUnmarshallClass() - Method in class org.apache.camel.model.dataformat.JibxDataFormat
 
getUnmarshallTypeName() - Method in class org.apache.camel.model.dataformat.JibxDataFormat
 
getUnmarshalSingleObject() - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
 
getUnmarshalType() - Method in class org.apache.camel.model.dataformat.BoonDataFormat
 
getUnmarshalType() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getUnmarshalType() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getUnmarshalType() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getUnmarshalTypeName() - Method in class org.apache.camel.model.dataformat.BoonDataFormat
 
getUnmarshalTypeName() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getUnmarshalTypeName() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getUnmarshalTypeName() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
getUnwrapSingleInstance() - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
getUptime() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getUptime() - Method in class org.apache.camel.impl.DefaultRoute
 
getUptimeMillis() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getUptimeMillis() - Method in class org.apache.camel.impl.DefaultRoute
 
getUri() - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
getUri() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
getUri() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
getUri() - Method in class org.apache.camel.model.FromDefinition
 
getUri() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getUri() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getUri() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getUri() - Method in class org.apache.camel.model.SagaActionUriDefinition
 
getUri() - Method in class org.apache.camel.model.SendDefinition
 
getUri() - Method in class org.apache.camel.model.ToDynamicDefinition
 
getUri() - Method in class org.apache.camel.model.transformer.EndpointTransformerDefinition
 
getUri() - Method in class org.apache.camel.model.validator.EndpointValidatorDefinition
 
getUri() - Method in class org.apache.camel.model.WireTapDefinition
 
getUri() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getUri() - Method in class org.apache.camel.processor.WireTapProcessor
 
getUriDelimiter() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
getUriDelimiter() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getUriDelimiter() - Method in class org.apache.camel.processor.RoutingSlip
 
getUris() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getUrl() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The Consul agent URL
getUrlSafe() - Method in class org.apache.camel.model.dataformat.Base64DataFormat
 
getUrn() - Method in class org.apache.camel.model.InputTypeDefinition
Get input type URN.
getUrn() - Method in class org.apache.camel.model.OutputTypeDefinition
Get output type URN.
getUseCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getUseDefaultObjectMapper() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getUsedForGeneratingNodeId() - Method in class org.apache.camel.model.rest.VerbDefinition
 
getUseExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getUseList() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getUseList() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getUseMaps() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getUseOrderedMaps() - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
getUseOriginalMessagePolicy() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getUseOriginalMessagePolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getUserName() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getUserName() - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
 
getUsername() - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
getUsername() - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
getUseSaxon() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
getUseXForwardHeaders() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getUsingIterator() - Method in class org.apache.camel.model.dataformat.ASN1DataFormat
 
getUsingIterator() - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
 
getUsingIterator() - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
 
getUsingParallelCompression() - Method in class org.apache.camel.model.dataformat.LZFDataFormat
 
getUuidGenerator() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getValidate() - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
getValidating() - Method in class org.apache.camel.model.dataformat.IcalDataFormat
 
getValidatorRegistry() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getValidators() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getValidators() - Method in interface org.apache.camel.model.ModelCamelContext
Gets the validators that can be referenced in the routes.
getValidators() - Method in class org.apache.camel.model.validator.ValidatorsDefinition
 
getValidParameterType(String) - Static method in class org.apache.camel.component.bean.BeanHelper
Determines and maps the given value is valid according to the supported values by the bean component.
getValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Gets the input value in this token
getValue() - Method in class org.apache.camel.model.dataformat.YAMLTypeFilterDefinition
 
getValue() - Method in class org.apache.camel.model.GlobalOptionDefinition
 
getValue() - Method in class org.apache.camel.model.PropertyDefinition
 
getValue() - Method in class org.apache.camel.model.rest.RestPropertyDefinition
 
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
This method is implemented by the sub-class and is called to retrieve an instance of the value that will be aggregated and forwarded to the receiving end point.
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategy
 
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 
GetVerbDefinition - Class in org.apache.camel.model.rest
Rest GET command
GetVerbDefinition() - Constructor for class org.apache.camel.model.rest.GetVerbDefinition
 
getVerbs() - Method in class org.apache.camel.model.rest.RestDefinition
 
getVersion() - Method in class org.apache.camel.impl.AbstractCamelContext
 
getVersion() - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
getWhen() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
getWhenClauses() - Method in class org.apache.camel.model.ChoiceDefinition
 
getWidth() - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
 
getWriteAsString() - Method in class org.apache.camel.model.language.JsonPathExpression
 
getWriteTimeoutMillis() - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
getXml() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getXmlCipherAlgorithm() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getXmlDataFormat() - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
 
getXmlMapper() - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
getXmlStreamWriterWrapper() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getXpath() - Method in exception org.apache.camel.builder.xml.InvalidXPathExpression
 
getXPathFactory() - Method in class org.apache.camel.builder.xml.XPathBuilder
Gets the xpath factory, can be null if no custom factory has been assigned.
getXpathFactory() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
GlobalOptionDefinition - Class in org.apache.camel.model
Models a string key/value pair for configuring some global options on a Camel context such as max debug log length.
GlobalOptionDefinition() - Constructor for class org.apache.camel.model.GlobalOptionDefinition
 
GlobalOptionsDefinition - Class in org.apache.camel.model
Models a series of string key/value pairs for configuring some global options on a Camel context such as max debug log length.
GlobalOptionsDefinition() - Constructor for class org.apache.camel.model.GlobalOptionsDefinition
 
groovy(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Groovy expression
groovy(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Groovy expression
GroovyExpression - Class in org.apache.camel.model.language
To use Groovy scripts in Camel expressions or predicates.
GroovyExpression() - Constructor for class org.apache.camel.model.language.GroovyExpression
 
GroovyExpression(String) - Constructor for class org.apache.camel.model.language.GroovyExpression
 
group - Variable in class org.apache.camel.builder.XMLTokenExpressionIterator
 
group(String) - Method in class org.apache.camel.model.RouteDefinition
Set the group name for this route
groupedBody() - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a GroupedBodyAggregationStrategy aggregation strategy.
GroupedBodyAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate body of input Message into a single combined Exchange holding all the aggregated bodies in a List of type Object as the message body.
GroupedBodyAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategy
 
groupedExchange() - Static method in class org.apache.camel.builder.AggregationStrategies
Creates a GroupedExchangeAggregationStrategy aggregation strategy.
GroupedExchangeAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in a List of Exchange as the message body.
GroupedExchangeAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
GroupedMessageAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate all Message into a single combined Exchange holding all the aggregated messages in a List of Message as the message body.
GroupedMessageAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 
groupIteratorExpression(Expression, String, String, boolean) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
groupKey(String) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Sets the group key to use.
groupKey(String) - Method in class org.apache.camel.model.HystrixDefinition
Sets the group key to use.
groupXmlIteratorExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
gzip() - Method in class org.apache.camel.builder.DataFormatClause
Uses the GZIP deflater data format
GzipDataFormat - Class in org.apache.camel.impl
GZip DataFormat for reading/writing data using gzip.
GzipDataFormat() - Constructor for class org.apache.camel.impl.GzipDataFormat
 
GzipDataFormat - Class in org.apache.camel.model.dataformat
The GZip data format is a message compression and de-compression format (which works with the popular gzip/gunzip tools).
GzipDataFormat() - Constructor for class org.apache.camel.model.dataformat.GzipDataFormat
 

H

handle(Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
Handles the incoming exchange.
handled(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handled(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handled(Expression) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handleException() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
handleFault() - Method in class org.apache.camel.model.RouteDefinition
Enable handle fault for this route.
HandleFault - Class in org.apache.camel.processor.interceptor
InterceptStrategy implementation to handle faults as exceptions on a RouteContext
HandleFault() - Constructor for class org.apache.camel.processor.interceptor.HandleFault
 
handleFault(Exchange) - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
Handles the fault message by converting it to an Exception
HandleFaultInterceptor - Class in org.apache.camel.processor.interceptor
 
HandleFaultInterceptor() - Constructor for class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
HandleFaultInterceptor(Processor) - Constructor for class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
handleSagaCompletion(Exchange, CamelSagaCoordinator, CamelSagaCoordinator, AsyncCallback) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
handleSleepInterruptedException(InterruptedException, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Called when a sleep is interrupted; allows derived classes to handle this case differently
handoverSynchronization(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
handoverSynchronization(Exchange, Predicate<Synchronization>) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
hangupInterceptorEnabled - Variable in class org.apache.camel.main.MainSupport
 
hasAnnotation(T) - Method in class org.apache.camel.component.bean.ParameterInfo
 
hasAnyMethodHandlerAnnotation() - Method in class org.apache.camel.component.bean.BeanInfo
Does any of the methods have a Canel @Handler annotation.
hasBodyParameter() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
hasComponent(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
hasCustomAnnotation() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasCustomIdAssigned() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Returns whether a custom id has been assigned
hasEndpoint(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
hasExceptionParameter() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasFunctionStartToken(String) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Does the expression include a simple function.
hasHandlerAnnotation() - Method in class org.apache.camel.component.bean.MethodInfo
 
hashCode() - Method in class org.apache.camel.component.bean.BeanInfoCacheKey
 
hashCode() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
hashCode() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
HashMapHeadersMapFactory - Class in org.apache.camel.impl
HashMap HeadersMapFactory which uses a plain HashMap.
HashMapHeadersMapFactory() - Constructor for class org.apache.camel.impl.HashMapHeadersMapFactory
 
hasInterceptorStrategy(Class<?>) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
hasMethod(String) - Method in class org.apache.camel.component.bean.BeanInfo
Do we have a method with the given name.
hasNext() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
hasNext() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
hasNext() - Method in class org.apache.camel.processor.ChoiceProcessor
 
hasNext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
hasNext() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
hasNext() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
hasNext() - Method in class org.apache.camel.processor.MulticastProcessor
 
hasNext() - Method in class org.apache.camel.processor.Pipeline
 
hasNext() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
hasNext() - Method in class org.apache.camel.processor.Resequencer
 
hasNext(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Are the more routing slip(s)?
hasNext() - Method in class org.apache.camel.processor.StreamResequencer
 
hasNext() - Method in class org.apache.camel.processor.TryProcessor
 
hasOutputs(List<ProcessorDefinition<?>>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Is there any outputs in the given list.
hasParameters() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasPublicConstructors() - Method in class org.apache.camel.component.bean.BeanInfo
Returns whether the bean class has any public constructors.
hasService(Object) - Method in class org.apache.camel.impl.AbstractCamelContext
 
hasService(Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
hasServices(Class<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
hasSimpleFunction(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Does the expression include a simple function.
hasStaticMethod(String) - Method in class org.apache.camel.component.bean.BeanInfo
Do we have a static method with the given name.
hasTimeoutOccurred() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
head() - Method in class org.apache.camel.model.rest.RestDefinition
 
head(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
head() - Method in class org.apache.camel.model.rest.VerbDefinition
 
head(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
header(String) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for headers on an exchange
header(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given header
header(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message header of the given name
header(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an inbound message header of the given name
header(String) - Static method in class org.apache.camel.language.header.HeaderLanguage
 
header(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
Adds a response header
header - Variable in class org.apache.camel.processor.RoutingSlip
 
headerExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the header value with the given name

Will fallback and look in properties if not found in headers.

headerExpression(String, Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the header value with the given name converted to the given type

Will fallback and look in properties if not found in headers.

headerExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the header value with the given name converted to the given type

Will fallback and look in properties if not found in headers.

HeaderExpression - Class in org.apache.camel.model.language
To use a Camel Message header in expressions or predicates.
HeaderExpression() - Constructor for class org.apache.camel.model.language.HeaderExpression
 
HeaderExpression(String) - Constructor for class org.apache.camel.model.language.HeaderExpression
 
headerExtractionEnabled - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
HeaderLanguage - Class in org.apache.camel.language.header
A language for header expressions.
HeaderLanguage() - Constructor for class org.apache.camel.language.header.HeaderLanguage
 
headers() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the inbound headers
headers() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the inbound headers
headers - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
headersDisabled - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
headersExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message headers
HeadersMapFactoryResolver - Class in org.apache.camel.impl
Factory to create the HeadersMapFactory implementation to be used.
HeadersMapFactoryResolver() - Constructor for class org.apache.camel.impl.HeadersMapFactoryResolver
 
headersOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message header invoking methods defined in a simple OGNL notation
HeadVerbDefinition - Class in org.apache.camel.model.rest
Rest HEAD command
HeadVerbDefinition() - Constructor for class org.apache.camel.model.rest.HeadVerbDefinition
 
health() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
healthy() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
healthyFilter() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
healthyFilter() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
HealthyServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
HealthyServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.HealthyServiceCallServiceFilterConfiguration
 
HealthyServiceCallServiceFilterConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.HealthyServiceCallServiceFilterConfiguration
 
HealthyServiceFilter - Class in org.apache.camel.impl.cloud
 
HealthyServiceFilter() - Constructor for class org.apache.camel.impl.cloud.HealthyServiceFilter
 
HealthyServiceFilterFactory - Class in org.apache.camel.impl.cloud
 
HealthyServiceFilterFactory() - Constructor for class org.apache.camel.impl.cloud.HealthyServiceFilterFactory
 
higher(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next higher element in the sequence to the given element.
hl7() - Method in class org.apache.camel.builder.DataFormatClause
Uses the HL7 data format
hl7(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the HL7 data format
hl7(Object) - Method in class org.apache.camel.builder.DataFormatClause
Uses the HL7 data format
HL7DataFormat - Class in org.apache.camel.model.dataformat
The HL7 data format can be used to marshal or unmarshal HL7 (Health Care) model objects.
HL7DataFormat() - Constructor for class org.apache.camel.model.dataformat.HL7DataFormat
 
hl7terser(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Hl7TerserExpression - Class in org.apache.camel.model.language
To use HL7 terser scripts in Camel expressions or predicates.
Hl7TerserExpression() - Constructor for class org.apache.camel.model.language.Hl7TerserExpression
 
Hl7TerserExpression(String) - Constructor for class org.apache.camel.model.language.Hl7TerserExpression
 
host() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
host(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To define the host to use, such as 0.0.0.0 or localhost
hostHeader(String) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
The header that holds the service host information, default ServiceCallConstants.SERVICE_HOST
hostNameResolver(RestHostNameResolver) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify the hostname resolver
hystrix() - Method in class org.apache.camel.model.ProcessorDefinition
Creates a Hystrix Circuit Breaker EIP.
hystrixConfiguration() - Method in class org.apache.camel.model.HystrixDefinition
Configures the Hystrix EIP

Use end when configuration is complete, to return back to the Hystrix EIP.

hystrixConfiguration(HystrixConfigurationDefinition) - Method in class org.apache.camel.model.HystrixDefinition
Configures the Hystrix EIP using the given configuration
hystrixConfiguration(String) - Method in class org.apache.camel.model.HystrixDefinition
Refers to a Hystrix configuration to use for configuring the Hystrix EIP.
HystrixConfigurationCommon - Class in org.apache.camel.model
 
HystrixConfigurationCommon() - Constructor for class org.apache.camel.model.HystrixConfigurationCommon
 
HystrixConfigurationDefinition - Class in org.apache.camel.model
Hystrix Circuit Breaker EIP configuration
HystrixConfigurationDefinition() - Constructor for class org.apache.camel.model.HystrixConfigurationDefinition
 
HystrixConfigurationDefinition(HystrixDefinition) - Constructor for class org.apache.camel.model.HystrixConfigurationDefinition
 
HystrixDefinition - Class in org.apache.camel.model
Hystrix Circuit Breaker EIP
HystrixDefinition() - Constructor for class org.apache.camel.model.HystrixDefinition
 

I

ical(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the iCal data format
IcalDataFormat - Class in org.apache.camel.model.dataformat
The iCal dataformat is used for working with iCalendar messages.
IcalDataFormat() - Constructor for class org.apache.camel.model.dataformat.IcalDataFormat
 
id() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
id(String) - Method in class org.apache.camel.model.NoOutputExpressionNode
 
id(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the id of this node
id(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the id of this node.
id(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
id - Variable in class org.apache.camel.processor.RoutingSlip
 
id - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
id - Variable in class org.apache.camel.processor.SendProcessor
 
id - Variable in class org.apache.camel.processor.TryProcessor
 
idempotentConsumer() - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer using a fluent builder.
idempotentConsumer(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer to avoid duplicate messages
idempotentConsumer(Expression, IdempotentRepository) - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer to avoid duplicate messages
IdempotentConsumer - Class in org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
IdempotentConsumer(Expression, IdempotentRepository, boolean, boolean, boolean, boolean, Processor) - Constructor for class org.apache.camel.processor.idempotent.IdempotentConsumer
 
IdempotentConsumerDefinition - Class in org.apache.camel.model
Filters out duplicate messages
IdempotentConsumerDefinition() - Constructor for class org.apache.camel.model.IdempotentConsumerDefinition
 
IdempotentConsumerDefinition(Expression, IdempotentRepository) - Constructor for class org.apache.camel.model.IdempotentConsumerDefinition
 
IdempotentOnCompletion - Class in org.apache.camel.processor.idempotent
On completion strategy for IdempotentConsumer.
IdempotentOnCompletion(IdempotentRepository, String, boolean, boolean) - Constructor for class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
IdentifiedType - Class in org.apache.camel.model
The unique identifier for a bean.
IdentifiedType() - Constructor for class org.apache.camel.model.IdentifiedType
 
idOrCreate(NodeIdFactory) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Gets the node id, creating one if not already set.
ifNotException(Throwable, Exchange, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ifNotException(Throwable, Exchange, boolean, CamelSagaCoordinator, CamelSagaCoordinator, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ignoreInvalidCasts() - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Ignores invalid casts instead of throwing an exception if the pick expression result cannot be casted to the specified type.
ignoreInvalidCorrelationKeys() - Method in class org.apache.camel.model.AggregateDefinition
If a correlation key cannot be successfully evaluated it will be ignored by logging a DEBUG and then just ignore the incoming Exchange.
ignoreInvalidEndpoint() - Method in class org.apache.camel.model.EnrichDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoint() - Method in class org.apache.camel.model.PollEnrichDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoint() - Method in class org.apache.camel.model.ToDynamicDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoint() - Method in class org.apache.camel.model.WireTapDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoint - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ignoreInvalidEndpoints() - Method in class org.apache.camel.model.DynamicRouterDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoints() - Method in class org.apache.camel.model.RecipientListDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoints() - Method in class org.apache.camel.model.RoutingSlipDefinition
Ignore the invalidate endpoint exception when try to create a producer with that endpoint
ignoreInvalidEndpoints - Variable in class org.apache.camel.processor.RoutingSlip
 
ignoreInvalidExchanges() - Method in class org.apache.camel.model.ResequenceDefinition
If an incoming Exchange is invalid, then it will be ignored.
ignoreLeadingWhitespaces - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
ignoreTrailingWhitespaces - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
ImplicitCollectionEntry() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
ImplicitCollectionEntry(String, String[]) - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
ImplicitCollectionList() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionList
 
ImplicitCollectionsAdapter() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionsAdapter
 
in(Predicate...) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return true if any of the predicates matches.
in(List<Predicate>) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return true if any of the predicates matches.
in(Object...) - Method in class org.apache.camel.builder.ValueBuilder
 
in(Predicate...) - Method in class org.apache.camel.builder.ValueBuilder
 
IN_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
includeTokens - Variable in class org.apache.camel.builder.TokenPairExpressionIterator
 
incrementTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
index - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
inheritErrorHandler - Variable in class org.apache.camel.model.ProcessorDefinition
 
inheritErrorHandler(boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Sets whether or not to inherit the configured error handler.
inheritNamespaceToken - Variable in class org.apache.camel.builder.TokenXMLExpressionIterator
 
init(List<Class<?>>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
initCamelContext() - Method in class org.apache.camel.main.MainSupport
 
initChannel(ProcessorDefinition<?>, RouteContext) - Method in interface org.apache.camel.model.ModelChannel
Initializes the channel.
initChannel(ProcessorDefinition<?>, RouteContext) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
initialProperties - Variable in class org.apache.camel.main.MainSupport
 
initParent(ProcessorDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
 
injectClass(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectField(Field, String, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectField(Field, String, String, Object, String, boolean) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectFieldBean(Field, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectFieldProperty(Field, String, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectFields(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
A strategy method to allow implementations to perform some custom JBI based injection of the POJO
injectMethods(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
injectNestedClasses(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
inMessage() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message
inMessage(Function<Message, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message
inMessage() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an inbound message
inMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the IN message
inMessageExpression(Function<Message, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the IN message
inOnly(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Event Message or InOnly exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOnly(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Event Message or InOnly exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOnly(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOnly(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOnly(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

InOnlyDefinition - Class in org.apache.camel.model
Marks the exchange pattern for the route to one way
InOnlyDefinition() - Constructor for class org.apache.camel.model.InOnlyDefinition
 
InOnlyDefinition(String) - Constructor for class org.apache.camel.model.InOnlyDefinition
 
InOnlyDefinition(Endpoint) - Constructor for class org.apache.camel.model.InOnlyDefinition
 
inOut(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Request Reply or InOut exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOut(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Request Reply or InOut exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOut(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOut(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

inOut(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern

Notice the existing MEP is restored after the message has been sent to the given endpoint.

InOutDefinition - Class in org.apache.camel.model
Marks the exchange pattern for the route to request/reply
InOutDefinition() - Constructor for class org.apache.camel.model.InOutDefinition
 
InOutDefinition(String) - Constructor for class org.apache.camel.model.InOutDefinition
 
InOutDefinition(Endpoint) - Constructor for class org.apache.camel.model.InOutDefinition
 
inputType(String) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the input message.
inputType(Class) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the input message by Java class.
InputTypeDefinition - Class in org.apache.camel.model
Set the expected data type of the input message.
InputTypeDefinition() - Constructor for class org.apache.camel.model.InputTypeDefinition
 
inputTypeWithValidate(String) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the input message with content validation enabled.
inputTypeWithValidate(Class) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the input message by Java class with content validation enabled.
insert(E) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Inserts the given element into this resequencer.
instance - Static variable in class org.apache.camel.main.Main
 
intercept() - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts every processing step.
intercept() - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered on every step in the route processing.
InterceptDefinition - Class in org.apache.camel.model
Intercepts a message at each step in the route
InterceptDefinition() - Constructor for class org.apache.camel.model.InterceptDefinition
 
intercepted - Variable in class org.apache.camel.model.InterceptDefinition
 
InterceptEndpointProcessor - Class in org.apache.camel.processor
Endpoint intercept processor so we know the processor is supposed to intercept an endpoint.
InterceptEndpointProcessor(String, Processor) - Constructor for class org.apache.camel.processor.InterceptEndpointProcessor
 
interceptFrom() - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts incoming messages on any inputs in this route
interceptFrom(String) - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts incoming messages on the given endpoint.
interceptFrom() - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is received as input to any routes (eg from all the from)
interceptFrom(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is received as input to the route defined with the given endpoint (eg from the from)
InterceptFromDefinition - Class in org.apache.camel.model
Intercepts incoming messages
InterceptFromDefinition() - Constructor for class org.apache.camel.model.InterceptFromDefinition
 
InterceptFromDefinition(String) - Constructor for class org.apache.camel.model.InterceptFromDefinition
 
InterceptorToAsyncProcessorBridge - Class in org.apache.camel.processor
A bridge to have regular interceptors implemented as Processor work with the asynchronous routing engine without causing side effects.
InterceptorToAsyncProcessorBridge(Processor) - Constructor for class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
Constructs the bridge
interceptSendToEndpoint(String) - Method in class org.apache.camel.builder.RouteBuilder
Applies a route for an interceptor if an exchange is send to the given endpoint
interceptSendToEndpoint(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is send to the given endpoint
InterceptSendToEndpointDefinition - Class in org.apache.camel.model
Intercepts messages being sent to an endpoint
InterceptSendToEndpointDefinition() - Constructor for class org.apache.camel.model.InterceptSendToEndpointDefinition
 
InterceptSendToEndpointDefinition(String) - Constructor for class org.apache.camel.model.InterceptSendToEndpointDefinition
 
InterceptSendToEndpointProcessor - Class in org.apache.camel.impl
Processor used to interceptor and detour the routing when using the DefaultInterceptSendToEndpoint functionality.
InterceptSendToEndpointProcessor(DefaultInterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Constructor for class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
InterceptSendToMockEndpointStrategy - Class in org.apache.camel.impl
A EndpointStrategy which is capable of mocking endpoints.
InterceptSendToMockEndpointStrategy() - Constructor for class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
Mock all endpoints.
InterceptSendToMockEndpointStrategy(String) - Constructor for class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
Mock endpoints based on the given pattern.
InterceptSendToMockEndpointStrategy(String, boolean) - Constructor for class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
Mock endpoints based on the given pattern.
interrupt(String) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
interrupt(Exchange) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
InvalidXPathExpression - Exception in org.apache.camel.builder.xml
An exception thrown if am XPath expression could not be parsed or evaluated
InvalidXPathExpression(String, XPathException) - Constructor for exception org.apache.camel.builder.xml.InvalidXPathExpression
 
invoke(Object, Method, Object[]) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
invoke(Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInvocation
This causes us to invoke the endpoint Pojo using reflection.
invoke(Method, Object, Object[], Exchange) - Method in class org.apache.camel.component.bean.MethodInfo
 
invoke(Object, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
invokeProxy(Method, ExchangePattern, Object[], boolean) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
invokeWithBody(Method, Object, ExchangePattern) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
isAbstract() - Method in class org.apache.camel.model.InterceptDefinition
 
isAbstract() - Method in class org.apache.camel.model.InterceptFromDefinition
 
isAbstract() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
isAbstract() - Method in class org.apache.camel.model.OnCompletionDefinition
 
isAbstract() - Method in class org.apache.camel.model.OnExceptionDefinition
 
isAbstract() - Method in class org.apache.camel.model.PolicyDefinition
 
isAbstract() - Method in class org.apache.camel.model.ProcessorDefinition
Whether this model is abstract or not.
isAbstract() - Method in class org.apache.camel.model.SagaDefinition
 
isAbstract() - Method in class org.apache.camel.model.TransactedDefinition
 
isAcceptableScheme(String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
isAggregateOnException() - Method in class org.apache.camel.processor.Enricher
 
isAggregateOnException() - Method in class org.apache.camel.processor.PollEnricher
 
isAllowAnyType() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
isAllowDuplicates() - Method in class org.apache.camel.processor.Resequencer
 
isAllowNullNewExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowNullOldExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowOptimisedComponents() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isAllowRedeliveryWhileStopping() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isAllowUseOriginalMessage() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isAllowUseOriginalMessage() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isAnyOrder() - Method in class org.apache.camel.component.test.TestEndpoint
 
isAnySpoolRules() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
isAssignableToExpectedType(ClassResolver, String, Class<?>) - Static method in class org.apache.camel.component.bean.BeanHelper
Determines if the given parameter type is assignable to the expected type.
isAsyncDelayed() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isAsyncDelayed() - Method in class org.apache.camel.processor.Throttler
 
isAsyncDelayedRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
isAsyncDelayedRedelivery() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isAutoConfigurationEnabled() - Method in class org.apache.camel.main.MainSupport
 
isAutoCreateComponents() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isAutoStartup() - Method in class org.apache.camel.impl.AbstractCamelContext
 
IsAutoStartup() - Constructor for class org.apache.camel.impl.cluster.ClusteredRouteFilters.IsAutoStartup
 
isAutoStartup() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isAutoStartup(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
Deprecated.
isBatchConsumer() - Method in class org.apache.camel.processor.Resequencer
 
isBinary() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is binary operator
isBodyIncludeFiles() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isBodyIncludeFiles() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isBodyIncludeStreams() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isBodyIncludeStreams() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isBooleanValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
isBooleanValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isCache() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.Throttler
 
isCancelledOrInterrupted(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy to determine if the exchange was cancelled or interrupted
isCaseInsensitive() - Method in class org.apache.camel.impl.DefaultHeadersMapFactory
 
isCaseInsensitive() - Method in class org.apache.camel.impl.HashMapHeadersMapFactory
 
isCompleteAllOnStop() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isCompleted(String, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Tests whether the given exchange is complete or not
isCompletionEager() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isCompletionFromBatchConsumer() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isCompletionOnNewCorrelationGroup() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isContextScopedErrorHandler(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
 
isCopy() - Method in class org.apache.camel.processor.LoopProcessor
 
isCopy() - Method in class org.apache.camel.processor.WireTapProcessor
 
isCopyOnExchange() - Method in class org.apache.camel.component.mock.MockEndpoint
 
isCovariantWith(MethodInfo) - Method in class org.apache.camel.component.bean.MethodInfo
Returns true if this method is covariant with the specified method (this method may above or below the specified method in the class hierarchy)
isCreateCopy() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.DeadLetterChannel
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.ErrorHandlerSupport
Whether this error handler handles exhausted errors by moving the exchange to a dead letter channel.
isDeadLetterHandleNewException() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
isDeadLetterHandleNewException() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
isDefaultProfile() - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
isDisabled() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
isDiscardOnCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isDone(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy to determine if the exchange is done so we can continue
isDoubleQuote() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is double quote
isDynamic(K) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
isDynamic(String) - Method in class org.apache.camel.impl.DefaultEndpointRegistry
 
isDynamic(String) - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
isDynamic(DataType, DataType) - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
isDynamic(DataType) - Method in class org.apache.camel.impl.DefaultValidatorRegistry
 
isDynamic() - Method in class org.apache.camel.model.WireTapDefinition
 
isDynamicUri() - Method in class org.apache.camel.processor.WireTapProcessor
 
isEager() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isEagerCheckCompletion() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isEmpty() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
isEnabled() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
isEnabled(CamelEvent) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
isEnabled() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
isEnabled(CamelEvent) - Method in class org.apache.camel.main.MainDurationEventNotifier
 
isEnabled() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isEnabled() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isEncodeElementsAppliesToChildResourcesOnly() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
isEol() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is eol
isEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isEqualToIgnoreCase(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isEqualToIgnoreCase(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isErrorHandlerBuilderConfigured(String) - Static method in class org.apache.camel.builder.ErrorHandlerBuilderRef
Returns whether a specific error handler builder has been configured or not.
isEscape() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is escape
isEventNotifierEnabled() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
isEventNotifierEnabled() - Method in class org.apache.camel.impl.DefaultProducerCache
 
isEventNotifierEnabled() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
isExponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isExtendedStatistics() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
isExtendedStatistics() - Method in class org.apache.camel.impl.DefaultProducerCache
 
isFailed() - Method in class org.apache.camel.impl.DefaultSubUnitOfWork
 
isFallbackViaNetwork() - Method in class org.apache.camel.model.OnFallbackDefinition
 
isFileWatchDirectoryRecursively() - Method in class org.apache.camel.main.MainSupport
 
isFirstChildOfType(Class<?>, ProcessorDefinition<?>) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Is the given child the first in the outputs from the parent?
isFixedName() - Method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
 
isFixedName() - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
 
isFixedName() - Method in class org.apache.camel.impl.ExplicitCamelContextNameStrategy
 
isFunctionEnd() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a function end
isFunctionStart() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a function start
isFunctionSupport() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isGreaterThan(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isGreaterThanOrEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isGroupExchanges() - Method in class org.apache.camel.processor.Resequencer
 
isHandleFault() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isHandleFault() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isHealthy() - Method in class org.apache.camel.impl.cloud.DefaultServiceHealth
 
isIgnoreInvalidCorrelationKeys() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.Enricher
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.PollEnricher
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.WireTapProcessor
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RecipientList
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RecipientListProcessor
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RoutingSlip
 
isIgnoreInvalidExchanges() - Method in class org.apache.camel.processor.Resequencer
 
isIgnoreInvalidExchanges() - Method in class org.apache.camel.processor.StreamResequencer
 
isIncludeTokens() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isInheritErrorHandler() - Method in class org.apache.camel.model.ProcessorDefinition
 
isInputStreamNeeded(Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
Checks whether we need an InputStream to access the message body.
isInputStreamNeeded(Exchange, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Checks whether we need an InputStream to access the message header.
isInputStreamNeededForObject(Exchange, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Checks whether we need an InputStream to access this object

Depending on the content in the object, we may not need to convert to InputStream.

isInstanceOf(Expression, Class<?>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isInstanceOf(Class<?>) - Method in class org.apache.camel.builder.ValueBuilder
 
isInstanceOf(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultHeadersMapFactory
 
isInstanceOf(Map<String, Object>) - Method in class org.apache.camel.impl.HashMapHeadersMapFactory
 
isInterruptThreadsWhileStopping() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
isJMXDisabled() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isLeader() - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
isLenientProperties() - Method in class org.apache.camel.component.mock.MockEndpoint
 
isLenientProperties() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
isLessThan(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLessThanOrEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLiteralSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isLiteralWithFunctionSupport() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isLoadTypeConverters() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isLogContinued() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogExhausted() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogHandled() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogical() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is logical operator
isLogInflightExchangesOnTimeout() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
isLogMask() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isLogMask() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isLogNamespaces() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
isLogNewException() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogRetryAttempted() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogRetryStackTrace() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLogStackTrace() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isManaged(Object) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
isManagedName(Object) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
isMarkRollbackOnly() - Method in class org.apache.camel.processor.RollbackProcessor
 
isMarkRollbackOnlyLast() - Method in class org.apache.camel.processor.RollbackProcessor
 
isMatchingNamespaceOrEmptyNamespace(String, String) - Static method in class org.apache.camel.builder.xml.Namespaces
Returns true if the given namespaceURI is empty or if it matches the given expected namespace
isMessageHistory() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isMessageHistory() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isMinusValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a minus operator
isMinusValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isNotEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isNotNull(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotNull() - Method in class org.apache.camel.builder.ValueBuilder
 
isNull(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNull() - Method in class org.apache.camel.builder.ValueBuilder
 
isNullValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a null value
isNullValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isNumericValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isOmitResourceId() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
isOptimisticLocking() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isOutputSupported() - Method in class org.apache.camel.model.AggregateDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.CatchDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.ChoiceDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.ExpressionNode
 
isOutputSupported() - Method in class org.apache.camel.model.HystrixDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.NoOutputDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.NoOutputExpressionNode
 
isOutputSupported() - Method in class org.apache.camel.model.OnCompletionDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.OnExceptionDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.OutputDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.ProcessorDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.ResequenceDefinition
 
isOutputSupported() - Method in class org.apache.camel.model.RouteDefinition
 
isParallelAggregate() - Method in class org.apache.camel.processor.MulticastProcessor
 
isParallelAggregate() - Method in class org.apache.camel.processor.RecipientList
 
isParallelProcessing() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isParallelProcessing() - Method in class org.apache.camel.processor.MulticastProcessor
 
isParallelProcessing() - Method in class org.apache.camel.processor.RecipientList
 
isParentOfType(Class<? extends ProcessorDefinition>, ProcessorDefinition<?>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Is the given node parent(s) of the given type
isPreCompleted(String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Tests whether the given exchanges is pre-complete or not
isPrettyFlow() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
isPrettyPrint() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
isRandomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isRecursive() - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
isRedeliveryAllowed() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
isRegex() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isRejectExecution() - Method in class org.apache.camel.processor.Throttler
 
isRejectOld() - Method in class org.apache.camel.processor.StreamResequencer
 
isRemoveOnDump() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isRemoveOnFailure() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isRemoveSpoolDirectoryWhenStopping() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
isRemovingRoutes() - Method in class org.apache.camel.impl.RouteService
 
isReportGroup() - Method in class org.apache.camel.component.mock.MockEndpoint
 
isRest() - Method in class org.apache.camel.model.RouteDefinition
 
isReturnTypeVoid() - Method in class org.apache.camel.component.bean.MethodInfo
 
isReverse() - Method in class org.apache.camel.processor.Resequencer
 
isRoundRobin() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRouteAdded() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isRoutePolicyRunAllowed(RoutePolicy) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
Strategy to determine if this policy is allowed to run
isRouteScoped() - Method in class org.apache.camel.model.OnCompletionDefinition
 
isRouteScoped() - Method in class org.apache.camel.model.OnExceptionDefinition
 
isRunAllowed() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRunAllowed() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.DeadLetterChannel
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
isSetupRoutes() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.Enricher
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.MulticastProcessor
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.RecipientList
 
isShorthandMethod() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
isShorthandMethod() - Method in class org.apache.camel.component.bean.BeanProcessor
 
isShutdownExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
isShutdownNowOnTimeout() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
isShutdownOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isShutdownRoutesInReverseOrder() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
isShutdownTimeoutCheckerExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isSingleQuote() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is single quote
isSingleStepMode() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isSingleton() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
isSingleton() - Method in class org.apache.camel.component.mock.MockEndpoint
 
isSingleton(Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Implementations can override this method to determine if the bean is singleton.
isSingleton() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
isSingleton() - Method in class org.apache.camel.impl.DeferProducer
 
isSingleton() - Method in class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
isSingleton() - Method in class org.apache.camel.language.bean.BeanLanguage
 
isSingleton() - Method in class org.apache.camel.language.constant.ConstantLanguage
 
isSingleton() - Method in class org.apache.camel.language.header.HeaderLanguage
 
isSingleton() - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
isSingleton() - Method in class org.apache.camel.language.ref.RefLanguage
 
isSingleton() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isSingleton() - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
isSingleton() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
isSingleton() - Method in class org.apache.camel.processor.EventNotifierProducer
 
isSingleton() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
isSkip() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
isSkipDuplicate() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isSkipFirst() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isSplit() - Method in class org.apache.camel.component.test.TestEndpoint
 
isStartable(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
Deprecated.
isStartingRoutes() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isStartingRoutes() - Method in class org.apache.camel.impl.DefaultRouteController
 
isStatic(K) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
isStatic(String) - Method in class org.apache.camel.impl.DefaultEndpointRegistry
 
isStatic(String) - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
isStatic(DataType, DataType) - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
isStatic(DataType) - Method in class org.apache.camel.impl.DefaultValidatorRegistry
 
isStaticMethod() - Method in class org.apache.camel.component.bean.MethodInfo
 
isStatisticsEnabled() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Whether statistics is enabled.
isSticky() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isStopOnAggregateException() - Method in class org.apache.camel.processor.MulticastProcessor
 
isStopOnAggregateException() - Method in class org.apache.camel.processor.RecipientList
 
isStopOnException() - Method in class org.apache.camel.model.SplitDefinition
 
isStopOnException() - Method in class org.apache.camel.processor.MulticastProcessor
Should the multicast processor stop processing further exchanges in case of an exception occurred?
isStopOnException() - Method in class org.apache.camel.processor.RecipientList
 
isStoppable(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
Deprecated.
isStoreAsBodyOnCompletion() - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
Whether to store the completed aggregated List as message body, or to keep as property on the exchange.
isStreamCaching() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isStreamCaching() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isStreaming() - Method in class org.apache.camel.processor.MulticastProcessor
Is the multicast processor working in streaming mode?

In streaming mode: we use Iterable to ensure we can send messages as soon as the data becomes available for parallel processing, we start aggregating responses as they get send back to the processor; this means the AggregationStrategy has to take care of handling out-of-order arrival of exchanges

isStreaming() - Method in class org.apache.camel.processor.RecipientList
 
isSummaryMode() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
isSuppressLoggingOnTimeout() - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
isSuppressNarratives() - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
isThreadedAsyncMode() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
isThreadSafety() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
isTopLevelOnly() - Method in class org.apache.camel.model.InterceptDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.InterceptFromDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.OnExceptionDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.PolicyDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.ProcessorDefinition
Whether this definition can only be added as top-level directly on the route itself (such as onException,onCompletion,intercept, etc.)

If trying to add a top-level only definition to a nested output would fail in the ProcessorDefinition.addOutput(ProcessorDefinition) method.

isTopLevelOnly() - Method in class org.apache.camel.model.SagaDefinition
 
isTopLevelOnly() - Method in class org.apache.camel.model.TransactedDefinition
 
isTrace() - Method in class org.apache.camel.main.MainSupport
 
isTracing() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isTracing() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isTransacted() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
isTransactedBy(Object) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
isTypeConverterStatisticsEnabled() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isUnary() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is unary operator
isUseApplicationContextClassLoader() - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
isUseBreadcrumb() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isUseCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseDataType() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isUseExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseList() - Method in class org.apache.camel.model.dataformat.BoonDataFormat
 
isUseMDCLogging() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isUseOriginalMessage() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
isUseOriginalMessagePolicy() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
isUseSaxon() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
isValid(Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
isValid(E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if the o1 can be used in this comparator.
isValidate() - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
isValidate() - Method in class org.apache.camel.model.InputTypeDefinition
Get if validation is required for this input type.
isValidate() - Method in class org.apache.camel.model.OutputTypeDefinition
Get if validation is required for this output type.
isValidMethod(Method) - Method in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
isValidMethod(Class<?>, Method) - Method in class org.apache.camel.component.bean.BeanInfo
Validates whether the given method is a valid candidate for Camel Bean Binding.
isValidMethod(Method) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Validates whether the given method is valid.
isValidParameterValue(String) - Static method in class org.apache.camel.component.bean.BeanHelper
Determines if the given value is valid according to the supported values by the bean component.
isVetoStarted() - Method in class org.apache.camel.impl.AbstractCamelContext
 
isWebSphereClassLoader(ClassLoader) - Static method in class org.apache.camel.impl.WebSpherePackageScanClassResolver
Is the classloader from IBM and thus the WebSphere platform?
isWhitespace() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is whitespace
isWrappingEntireOutput() - Method in class org.apache.camel.model.PolicyDefinition
 
isWrappingEntireOutput() - Method in class org.apache.camel.model.ProcessorDefinition
Whether this definition is wrapping the entire output.
isWrappingEntireOutput() - Method in class org.apache.camel.model.SagaDefinition
 
isWrappingEntireOutput() - Method in class org.apache.camel.model.TransactedDefinition
 
isXml() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 

J

jacksonxml() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(Class<?>, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format using the Jackson library turning pretty printing on or off
jacksonxml(Class<?>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(Class<?>, Class<?>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(Class<?>, Class<?>, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
jacksonxml(Class<?>, Class<?>, String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson XML data format
JacksonXMLDataFormat - Class in org.apache.camel.model.dataformat
JacksonXML data format is used for unmarshal a XML payload to POJO or to marshal POJO back to XML payload.
JacksonXMLDataFormat() - Constructor for class org.apache.camel.model.dataformat.JacksonXMLDataFormat
 
javaScript(String) - Method in class org.apache.camel.builder.ExpressionClause
Deprecated.
JavaScript is deprecated in Java 11 onwards
javaScript(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Deprecated.
JavaScript is deprecated in Java 11 onwards
JavaScriptExpression - Class in org.apache.camel.model.language
Deprecated.
JavaScript is deprecated in Java 11 onwards
JavaScriptExpression() - Constructor for class org.apache.camel.model.language.JavaScriptExpression
Deprecated.
 
JavaScriptExpression(String) - Constructor for class org.apache.camel.model.language.JavaScriptExpression
Deprecated.
 
JavaUuidGenerator - Class in org.apache.camel.impl
This implementation uses the UUID from Java.
JavaUuidGenerator() - Constructor for class org.apache.camel.impl.JavaUuidGenerator
 
jaxb() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format
jaxb(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format with context path
jaxb(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format turning pretty printing on or off
JAXB_CONTEXT_PACKAGES - Static variable in class org.apache.camel.model.Constants
 
JaxbDataFormat - Class in org.apache.camel.model.dataformat
JAXB data format uses the JAXB2 XML marshalling standard to unmarshal an XML payload into Java objects or to marshal Java objects into an XML payload.
JaxbDataFormat() - Constructor for class org.apache.camel.model.dataformat.JaxbDataFormat
 
JaxbDataFormat(boolean) - Constructor for class org.apache.camel.model.dataformat.JaxbDataFormat
 
jibx() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JiBX data format.
jibx(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JiBX data format with unmarshall class.
JibxDataFormat - Class in org.apache.camel.model.dataformat
JiBX data format is used for unmarshal a XML payload to POJO or to marshal POJO back to XML payload.
JibxDataFormat() - Constructor for class org.apache.camel.model.dataformat.JibxDataFormat
 
JibxDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.JibxDataFormat
 
JndiRegistry - Class in org.apache.camel.impl
Deprecated.
use JndiBeanRepository instead.
JndiRegistry() - Constructor for class org.apache.camel.impl.JndiRegistry
Deprecated.
 
JndiRegistry(Map) - Constructor for class org.apache.camel.impl.JndiRegistry
Deprecated.
 
JndiRegistry(Context) - Constructor for class org.apache.camel.impl.JndiRegistry
Deprecated.
 
JndiRegistry(boolean) - Constructor for class org.apache.camel.impl.JndiRegistry
Deprecated.
 
json() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format using the XStream json library
json(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format using the XStream json library turning pretty printing on or off
json(JsonLibrary) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
json(JsonLibrary, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
json(JsonLibrary, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
json(JsonLibrary, Class<?>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
json(Class<?>, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson JSON data format
json(Class<?>, Class<?>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson JSON data format
json(Class<?>, Class<?>, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson JSON data format
json(Class<?>, Class<?>, String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Jackson JSON data format
JsonDataFormat - Class in org.apache.camel.model.dataformat
JSon data format is used for unmarshal a JSon payload to POJO or to marshal POJO back to JSon payload.
JsonDataFormat() - Constructor for class org.apache.camel.model.dataformat.JsonDataFormat
 
JsonDataFormat(JsonLibrary) - Constructor for class org.apache.camel.model.dataformat.JsonDataFormat
 
jsonDataFormat(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific json data format

Important: This option is only for setting a custom name of the data format, not to refer to an existing data format instance.

JsonLibrary - Enum in org.apache.camel.model.dataformat
Represents the concrete Json libraries Camel supports.
jsonpath(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a JSonPath expression value builder
jsonpath(String, Class<?>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a JSonPath expression value builder
jsonpath(String) - Method in class org.apache.camel.builder.ExpressionClause
jsonpath(String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
jsonpath(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
jsonpath(String, boolean, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
jsonpath(String, boolean, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClause
jsonpath(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, boolean, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, boolean, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, boolean, boolean, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
jsonpath(String, boolean, boolean, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
JsonPathExpression - Class in org.apache.camel.model.language
To use JsonPath in Camel expressions or predicates.
JsonPathExpression() - Constructor for class org.apache.camel.model.language.JsonPathExpression
 
JsonPathExpression(String) - Constructor for class org.apache.camel.model.language.JsonPathExpression
 
jsonpathWriteAsString(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String, boolean, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String, boolean, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Json Path expression with writeAsString enabled.
jsonpathWriteAsString(String, boolean, boolean, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Json Path expression with writeAsString enabled.

K

keepAliveTime(long, TimeUnit) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
keepAliveTime(long) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
keepAliveTime(Long, TimeUnit) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
keepAliveTime(Long) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
keepAliveTime(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Keep-alive time in minutes.
keepAliveTime(long) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
keepAliveTime(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
keepAliveTime(long) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the keep alive time for idle threads
key(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
To use a specific key for claim check id.
kubernetesClientServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
kubernetesClientServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
kubernetesDnsServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
kubernetesDnsServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
kubernetesEnvServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
kubernetesEnvServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
KubernetesServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
KubernetesServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
KubernetesServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
 
kubernetesServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
kubernetesServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
kubernetesServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
kubernetesServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 

L

language(String, String) - Static method in class org.apache.camel.builder.Builder
Returns a constant expression
language(String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a language expression value builder
language(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a given language name with the expression text
language(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a given language name with the expression text
LANGUAGE_RESOLVER_RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LANGUAGE_RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LanguageAnnotation - Annotation Type in org.apache.camel.language
Base annotation for languages.
languageExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for evaluating the expression/predicate using the given language
LanguageExpression - Annotation Type in org.apache.camel.language
Base annotation for language expressions.
LanguageExpression - Class in org.apache.camel.model.language
To use the specified language in Camel expressions or predicates.
LanguageExpression() - Constructor for class org.apache.camel.model.language.LanguageExpression
 
LanguageExpression(String, String) - Constructor for class org.apache.camel.model.language.LanguageExpression
 
languageFactory - Variable in class org.apache.camel.impl.DefaultLanguageResolver
 
languageResolver - Variable in class org.apache.camel.impl.DefaultLanguageResolver
 
latch - Variable in class org.apache.camel.main.MainSupport
 
lazyEval(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
lazyLoad - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
LimitedPollingConsumerPollStrategy - Class in org.apache.camel.impl
A PollingConsumerPollStrategy which supports suspending consumers if they failed for X number of times in a row.
LimitedPollingConsumerPollStrategy() - Constructor for class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
lineSeparator - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
listAllRestServices() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
ListDataSet - Class in org.apache.camel.component.dataset
A DataSet that allows a list of static payloads to be used to create each message exchange along with using a pluggable transformer to customize the messages.
ListDataSet() - Constructor for class org.apache.camel.component.dataset.ListDataSet
 
ListDataSet(List<Object>) - Constructor for class org.apache.camel.component.dataset.ListDataSet
 
listeners - Variable in class org.apache.camel.main.MainSupport
 
LiteralExpression - Class in org.apache.camel.language.simple.ast
Represents literals in the AST.
LiteralExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.LiteralExpression
 
LiteralNode - Interface in org.apache.camel.language.simple.ast
Represents a node in the AST which contains literals
load(TypeConverterRegistry) - Method in class org.apache.camel.component.bean.BeanConverterLoader
 
loadAllResourcesAsURL(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadBalance(LoadBalancer) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses a custom load balancer
loadBalance() - Method in class org.apache.camel.model.ProcessorDefinition
Load Balancer EIP: Creates a loadbalance
loadBalance(LoadBalancer) - Method in class org.apache.camel.model.ProcessorDefinition
Load Balancer EIP: Creates a loadbalance
LoadBalanceDefinition - Class in org.apache.camel.model
Balances message processing among a number of nodes
LoadBalanceDefinition() - Constructor for class org.apache.camel.model.LoadBalanceDefinition
 
loadBalancer(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceLoadBalancer to use.
loadBalancer(ServiceLoadBalancer) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceLoadBalancer to use.
loadBalancer(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceLoadBalancer to use.
loadBalancer(ServiceLoadBalancer) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceLoadBalancer to use.
LoadBalancer - Interface in org.apache.camel.processor.loadbalancer
A strategy for load balancing across a number of Processor instances
loadBalancerConfiguration(ServiceCallServiceLoadBalancerConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the LoadBalancer using the given configuration.
loadBalancerConfiguration(ServiceCallServiceLoadBalancerConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the LoadBalancer using the given configuration.
LoadBalancerConsumer - Class in org.apache.camel.processor.loadbalancer
Represents a consumer which on starting registers itself with a LoadBalancer and on closing unregisters itself with a load balancer
LoadBalancerConsumer(Endpoint, Processor, LoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
LoadBalancerDefinition - Class in org.apache.camel.model
Balances message processing among a number of nodes
LoadBalancerDefinition() - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
LoadBalancerDefinition(LoadBalancer) - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
LoadBalancerDefinition(String) - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
LoadBalancerReifier<T extends LoadBalancerDefinition> - Class in org.apache.camel.reifier.loadbalancer
 
LoadBalancerSupport - Class in org.apache.camel.processor.loadbalancer
A default base class for a LoadBalancer implementation.
LoadBalancerSupport() - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
loadClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadConfigurations(CamelContext) - Method in class org.apache.camel.main.MainSupport
 
loadDefaultRegistry() - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
 
loadResourceAsStream(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadResourceAsURL(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadResourcesAsURL(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadRestsDefinition(CamelContext, InputStream) - Static method in class org.apache.camel.model.ModelHelper
 
loadRouteBuilders(CamelContext) - Method in class org.apache.camel.main.MainSupport
 
loadRoutesDefinition(CamelContext, InputStream) - Static method in class org.apache.camel.model.ModelHelper
Marshal the xml to the model definition
loadRoutesDefinition(CamelContext, Node) - Static method in class org.apache.camel.model.ModelHelper
Marshal the xml to the model definition
loadStore() - Method in class org.apache.camel.impl.FileStateRepository
Loads the given file store into the 1st level cache
log(Logger) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log(Class<?>) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log - Variable in class org.apache.camel.builder.RouteBuilder
 
LOG - Static variable in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
log - Variable in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
log - Variable in class org.apache.camel.impl.ReloadStrategySupport
 
LOG - Static variable in class org.apache.camel.main.MainSupport
 
log - Variable in class org.apache.camel.model.ProcessorDefinition
 
log(String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at INFO level.
log(LoggingLevel, String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at the given level.
log(LoggingLevel, String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at the given level and name.
log(LoggingLevel, Logger, String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at the given level using provided logger.
log(LoggingLevel, String, String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at the given level and name.
log(LoggingLevel, Logger, String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a log message to be logged at the given level using provided logger.
log - Variable in class org.apache.camel.reifier.ProcessorReifier
 
logContinued(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log errors even if its continued
logContinued(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log errors even if its continued (supports property placeholders)
logContinued(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether continued exceptions should be logged or not.
logContinued(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether continued exceptions should be logged or not (supports property placeholders).
logContinued - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
LogDefinition - Class in org.apache.camel.model
Logs the defined message to the logger
LogDefinition() - Constructor for class org.apache.camel.model.LogDefinition
 
LogDefinition(String) - Constructor for class org.apache.camel.model.LogDefinition
 
logExhausted(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logExhausted(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted exceptions
logExhausted(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted exceptions (supports property placeholders)
logExhausted(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted exceptions should be logged or not.
logExhausted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted exceptions should be logged or not (supports property placeholders).
logExhausted - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logExhausted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log exhausted errors
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted message body with message history.
logExhaustedMessageBody(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted message body with message history.
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted message body should be logged including message history or not (supports property placeholders).
logExhaustedMessageBody(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted message body should be logged including message history or not (supports property placeholders).
logExhaustedMessageBody - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log exhausted errors including message body (requires message history to be enabled)
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted exceptions with message history
logExhaustedMessageHistory(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log exhausted exceptions with message history
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted exceptions should be logged including message history or not (supports property placeholders).
logExhaustedMessageHistory(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether exhausted exceptions should be logged including message history or not (supports property placeholders).
logExhaustedMessageHistory - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log exhausted errors including message history
logger - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logger(CamelLogger) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the logger used for caught exceptions
logger - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
loggingLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the logging level of exceptions caught
logHandled(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logHandled(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log errors even if its handled
logHandled(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log errors even if its handled (supports property placeholders)
logHandled(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether handled exceptions should be logged or not.
logHandled(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether handled exceptions should be logged or not (supports property placeholders).
logHandled - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logHandled(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log errors even if its handled
LogicalExpression - Class in org.apache.camel.language.simple.ast
Represents a logical expression in the AST
LogicalExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.LogicalExpression
 
logicalOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
LogicalOperatorType - Enum in org.apache.camel.language.simple.types
Types of logical operators supported
logInflightExchanges(CamelContext, List<RouteStartupOrder>, boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
Logs information about the inflight exchanges
logMask() - Method in class org.apache.camel.model.RouteDefinition
Enable security mask for Logging on this route.
logMask(String) - Method in class org.apache.camel.model.RouteDefinition
Sets whether security mask for logging is enabled on this route.
logNamespaces() - Method in class org.apache.camel.builder.xml.XPathBuilder
Activates trace logging of all discovered namespaces in the message - to simplify debugging namespace-related issues

Namespaces are printed in Hashmap style {xmlns:prefix=[namespaceURI], xmlns:prefix=[namespaceURI]}.

logNewException(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logNewException(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether new exceptions should be logged or not (supports property placeholders).
logNewException(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether new exceptions should be logged or not (supports property placeholders).
logNewException(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether new exceptions should be logged or not.
logNewException(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether new exceptions should be logged or not (supports property placeholders).
logNewException - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logNewException(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether errors should be logged when a new exception occurred during handling a previous exception
LogProcessor - Class in org.apache.camel.processor
A processor which evaluates an Expression and logs it.
LogProcessor(Expression, CamelLogger, MaskingFormatter, Set<LogListener>) - Constructor for class org.apache.camel.processor.LogProcessor
 
logRetryAttempted(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logRetryAttempted(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log retry attempts
logRetryAttempted(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log retry attempts (supports property placeholders)
logRetryAttempted(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether retry attempts should be logged or not.
logRetryAttempted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether retry attempts should be logged or not (supports property placeholders).
logRetryAttempted - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logRetryAttempted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log retry attempts
logRetryStackTrace(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logRetryStackTrace(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log stacktrace for failed redelivery attempts
logRetryStackTrace(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log stacktrace for failed redelivery attempts (supports property placeholders)
logRetryStackTrace(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether stack traces should be logged when an retry attempt failed.
logRetryStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether stack traces should be logged when an retry attempt failed (supports property placeholders).
logRetryStackTrace - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logRetryStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log stacktrace for failed redelivery attempts
logRouteState(Route, String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
logStackTrace(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logStackTrace(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log stacktrace for failed messages.
logStackTrace(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether to log stacktrace for failed messages (supports property placeholders)
logStackTrace(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether stack traces should be logged.
logStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets whether stack traces should be logged (supports property placeholders) Can be used to include or reduce verbose.
logStackTrace - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether to log stacktrace for failed messages.
lookup(String, Class<T>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
lookup(String) - Method in class org.apache.camel.main.Main
Using the given name does lookup for the bean being already bound using the Main.bind(String, Object) method.
lookup(String, Class<T>) - Method in class org.apache.camel.main.Main
Using the given name and type does lookup for the bean being already bound using the Main.bind(String, Object) method.
lookup(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
lookupBean() - Method in class org.apache.camel.component.bean.RegistryBean
 
lookupByType(Class<T>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
lookupByType(Class<T>) - Method in class org.apache.camel.main.Main
Using the given type does lookup for the bean being already bound using the Main.bind(String, Object) method.
lookupErrorHandlerBuilder(RouteContext, String) - Static method in class org.apache.camel.builder.ErrorHandlerBuilderRef
Lookup the error handler by the given ref
lookupErrorHandlerBuilder(RouteContext, String, boolean) - Static method in class org.apache.camel.builder.ErrorHandlerBuilderRef
Lookup the error handler by the given ref
lookupErrorHandlerBuilder(ModelCamelContext) - Static method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
lookupExecutorServiceRef(RouteContext, String, Object, String) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Will lookup in Registry for a ExecutorService registered with the given executorServiceRef name.
lookupRests(ModelCamelContext) - Method in class org.apache.camel.model.RestContextRefDefinition
 
lookupRests(ModelCamelContext, String) - Static method in class org.apache.camel.model.RestContextRefDefinitionHelper
Lookup the rests from the RestContextRefDefinition.
lookupRoutes(ModelCamelContext) - Method in class org.apache.camel.model.RouteContextRefDefinition
 
lookupRoutes(ModelCamelContext, String) - Static method in class org.apache.camel.model.RouteContextRefDefinitionHelper
Lookup the routes from the RouteContextRefDefinition.
lookupScheduledExecutorServiceRef(RouteContext, String, Object, String) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Will lookup in Registry for a ScheduledExecutorService registered with the given executorServiceRef name.
lookupService(CamelContext) - Static method in class org.apache.camel.impl.cloud.ServiceRegistryHelper
 
lookupService(CamelContext, ServiceRegistry.Selector) - Static method in class org.apache.camel.impl.cloud.ServiceRegistryHelper
 
loop() - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
loop(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
loop(int) - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
LoopDefinition - Class in org.apache.camel.model
Processes a message multiple times
LoopDefinition() - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopDefinition(Expression) - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopDefinition(Predicate) - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.LoopDefinition
 
loopDoWhile(Predicate) - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a while loop allowing to process the a message while the predicate matches and possibly process them in a different way.
loopDoWhile() - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way using a fluent builder.
LoopProcessor - Class in org.apache.camel.processor
The processor which sends messages in a loop.
LoopProcessor(Processor, Expression, Predicate, boolean) - Constructor for class org.apache.camel.processor.LoopProcessor
 
lower(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next lower element in the sequence to the given element.
lzf() - Method in class org.apache.camel.builder.DataFormatClause
Uses the LZF deflater data format
LZFDataFormat - Class in org.apache.camel.model.dataformat
The LZF data format is a message compression and de-compression format (uses the LZF deflate algorithm).
LZFDataFormat() - Constructor for class org.apache.camel.model.dataformat.LZFDataFormat
 

M

Main - Class in org.apache.camel.main
A Main class for booting up Camel in standalone mode.
Main() - Constructor for class org.apache.camel.main.Main
 
Main(Class...) - Constructor for class org.apache.camel.main.Main
 
main(String...) - Static method in class org.apache.camel.main.Main
 
MainDurationEventNotifier - Class in org.apache.camel.main
A EventNotifier to trigger shutdown of the Main JVM when maximum number of messages has been processed.
MainDurationEventNotifier(CamelContext, int, long, AtomicBoolean, CountDownLatch, boolean) - Constructor for class org.apache.camel.main.MainDurationEventNotifier
 
MainLifecycleStrategy - Class in org.apache.camel.main
A LifecycleStrategy to trigger shutdown of the Main JVM when CamelContext is stopped from JMX or its stop method is invoked from Java code.
MainLifecycleStrategy(AtomicBoolean, CountDownLatch) - Constructor for class org.apache.camel.main.MainLifecycleStrategy
 
MainListener - Interface in org.apache.camel.main
A lifecycle listener to receive callbacks when the Main is started and stopped.
MainListenerSupport - Class in org.apache.camel.main
A useful base class for MainListener implementations.
MainListenerSupport() - Constructor for class org.apache.camel.main.MainListenerSupport
 
MainRegistry - Class in org.apache.camel.main
 
MainRegistry() - Constructor for class org.apache.camel.main.MainRegistry
 
MainSupport - Class in org.apache.camel.main
Base class for main implementations to allow starting up a JVM with Camel embedded.
MainSupport(Class...) - Constructor for class org.apache.camel.main.MainSupport
 
MainSupport() - Constructor for class org.apache.camel.main.MainSupport
 
MainSupport.Option - Class in org.apache.camel.main
 
MainSupport.ParameterOption - Class in org.apache.camel.main
 
makeProcessor(RouteContext) - Method in class org.apache.camel.reifier.ProcessorReifier
Creates the processor and wraps it in any necessary interceptors and error handlers
manageObject(Object) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
manageProcessor(NamedNode) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
mandatoryBodyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
mandatoryBodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type.
mandatoryBodyExpression(Class<T>, boolean) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
mandatoryBodyOgnlExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type and invoking methods on the converted body defined in a simple OGNL notation
mandatoryLookup(String, Class<T>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
mandatoryLookupService(CamelContext) - Static method in class org.apache.camel.impl.cloud.ServiceRegistryHelper
 
mandatoryLookupService(CamelContext, ServiceRegistry.Selector) - Static method in class org.apache.camel.impl.cloud.ServiceRegistryHelper
 
MandatorySagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the MANDATORY propagation mode.
MandatorySagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.MandatorySagaProcessor
 
markPrepared() - Method in class org.apache.camel.model.RouteDefinition
Marks the route definition as prepared.
markRollbackOnly() - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback only.
markRollbackOnlyLast() - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback only, but only for the last (current) transaction.
markUnprepared() - Method in class org.apache.camel.model.RouteDefinition
Marks the route definition as un-prepared.
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.GzipDataFormat
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.SerializationDataFormat
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.StringDataFormat
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.ZipDataFormat
 
marshal(Map<String, String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasAdapter
 
marshal(List<String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConvertersAdapter
 
marshal(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionsAdapter
 
marshal(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldsAdapter
 
marshal() - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Marshals the in body using a DataFormat expression to define the format of the output which will be added to the out body.
marshal(DataFormatDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Marshals the in body using the specified DataFormat and sets the output on the out message body.
marshal(DataFormat) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Marshals the in body using the specified DataFormat and sets the output on the out message body.
marshal(String) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Marshals the in body the specified DataFormat reference in the Registry and sets the output on the out message body.
marshal(TimeUnit) - Method in class org.apache.camel.model.TimeUnitAdapter
 
MarshalDefinition - Class in org.apache.camel.model
Marshals data into a specified format for transmission over a transport or component
MarshalDefinition() - Constructor for class org.apache.camel.model.MarshalDefinition
 
MarshalDefinition(DataFormatDefinition) - Constructor for class org.apache.camel.model.MarshalDefinition
 
masterUrl(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the URL to the master when using client lookup
matchContext(String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Does the given context match this camel context
matches(Exchange) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
matches(Exchange, Object, Object) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
matches() - Method in class org.apache.camel.builder.NotifyBuilder
Does all the expression match?

This operation will return immediately which means it can be used for testing at this very moment.

matches(long, TimeUnit) - Method in class org.apache.camel.builder.NotifyBuilder
Does all the expression match?

This operation will wait until the match is true or otherwise a timeout occur which means false will be returned.

matches(Exchange) - Method in class org.apache.camel.builder.PredicateClause
 
matches(Exchange) - Method in class org.apache.camel.builder.SimpleBuilder
 
matches(Exchange) - Method in class org.apache.camel.builder.TokenPairExpressionIterator
 
matches(Exchange) - Method in class org.apache.camel.builder.TokenXMLExpressionIterator
 
matches(Exchange) - Method in class org.apache.camel.builder.ValueBuilder
 
matches(Expression) - Method in class org.apache.camel.builder.ValueBuilder
 
matches() - Method in class org.apache.camel.builder.ValueBuilder
 
matches(Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
matches(CamelContext, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Matches the given xpath using the provided body.
matches(Exchange) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
matches(Exchange) - Method in class org.apache.camel.component.mock.TimeClause
 
matches(Exchange, Object, Object) - Method in class org.apache.camel.component.mock.TimeClause
 
matches(Exchange) - Method in class org.apache.camel.language.bean.BeanExpression
 
matches(Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
matches(Exchange) - Method in class org.apache.camel.processor.FilterProcessor
 
matchesMockWaitTime() - Method in class org.apache.camel.builder.NotifyBuilder
Does all the expressions match?

This operation will wait until the match is true or otherwise a timeout occur which means false will be returned.

matchesReturningFailureMessage(Exchange) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
matchesReturningFailureMessage(Exchange) - Method in class org.apache.camel.component.mock.TimeClause
 
matchesWhen(Exchange) - Method in class org.apache.camel.processor.CatchProcessor
Strategy method for matching the exception type with the current exchange.
matchesWhen(OnExceptionDefinition, Exchange) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy method for matching the exception type with the current exchange.
matchPattern(String, Endpoint, String) - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
Does the pattern match the endpoint?
MAX_BACKLOG_SIZE - Static variable in class org.apache.camel.processor.interceptor.BacklogTracer
 
maxCacheSize - Variable in class org.apache.camel.impl.AbstractDynamicRegistry
 
maxCapacity() - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
maxDeep(int) - Method in class org.apache.camel.builder.AdviceWithBuilder
Will only apply for nodes maximum levels deep.
maximumRedeliveries(int) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
maximumRedeliveries(int) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum redeliveries 5 = default value 0 = no redeliveries -1 = redeliver forever
maximumRedeliveries(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum redeliveries (supports property placeholders) 5 = default value 0 = no redeliveries -1 = redeliver forever
maximumRedeliveries(int) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum redeliveries x = redeliver at most x times 0 = no redeliveries -1 = redeliver forever
maximumRedeliveries(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum redeliveries (supports property placeholders) x = redeliver at most x times 0 = no redeliveries -1 = redeliver forever
maximumRedeliveries - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
maximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered
maximumRedeliveryDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum delay between redelivery
maximumRedeliveryDelay(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum delay between redelivery (supports property placeholders)
maximumRedeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum delay between redelivery
maximumRedeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum delay between redelivery (supports property placeholders)
maximumRedeliveryDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum redelivery delay if using exponential back off.
maximumRequestsPerPeriod(long) - Method in class org.apache.camel.model.ThrottleDefinition
Sets the time period during which the maximum request count per period
maximumRetries(int) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
Sets the maximum number of retries
maximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maximumRetryDelay(long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
Sets the upper value of retry in millis between retries, when using exponential or random backoff
maximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maximumSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Maximum thread-pool size that gets passed to ThreadPoolExecutor.setMaximumPoolSize(int).
maxPoolSize(int) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
maxPoolSize(Integer) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
maxPoolSize(int) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
maxPoolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
maxPoolSize(int) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the maximum pool size
maxQueueSize(int) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
maxQueueSize(Integer) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
maxQueueSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Max queue size.
maxQueueSize(int) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
maxQueueSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
maxQueueSize(int) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the maximum number of tasks in the work queue.
MDCUnitOfWork - Class in org.apache.camel.impl
This unit of work supports MDC.
MDCUnitOfWork(Exchange) - Constructor for class org.apache.camel.impl.MDCUnitOfWork
 
MemoryAggregationRepository - Class in org.apache.camel.processor.aggregate
A memory based AggregationRepository which stores Exchanges in memory only.
MemoryAggregationRepository() - Constructor for class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
MemoryAggregationRepository(boolean) - Constructor for class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
MemoryStateRepository - Class in org.apache.camel.impl
This MemoryStateRepository class is a memory-based implementation of a StateRepository.
MemoryStateRepository() - Constructor for class org.apache.camel.impl.MemoryStateRepository
 
message(BiFunction<Message, Message, Message>) - Method in class org.apache.camel.builder.AggregationStrategyClause
Define an aggregation strategy which targets Exchanges In Message.
message() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message
message(Function<Message, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an inbound message
message(Predicate<Message>) - Method in class org.apache.camel.builder.PredicateClause
Define a Predicate which targets the Exchange In Message.
message(Consumer<Message>) - Method in class org.apache.camel.builder.ProcessClause
Define a Processor which targets the Exchange In Message.
message(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an assertion to the given message index
message(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
The response message (description)
messageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the IN message
messageExpression(Function<Message, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the IN message
messageHistory() - Method in class org.apache.camel.model.RouteDefinition
Enable message history for this route.
messageHistory(String) - Method in class org.apache.camel.model.RouteDefinition
Enable message history for this route.
MessageHistoryAdvice(MessageHistoryFactory, ProcessorDefinition<?>) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
messageHistoryExpression(boolean) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the message history (including exchange details or not)
messageIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an Expression for the inbound message id
messageIdRepository(IdempotentRepository) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets the message id repository for the idempotent consumer
messageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets the reference name of the message id repository
MessageRejectedException - Exception in org.apache.camel.processor.resequencer
An exception thrown if message is rejected by the resequencer
MessageRejectedException(String) - Constructor for exception org.apache.camel.processor.resequencer.MessageRejectedException
 
MessageVariableResolver - Class in org.apache.camel.builder.xml
A variable resolver for XPath expressions which support properties on the message, exchange as well as making system properties and environment properties available.
MessageVariableResolver(ThreadLocal<Exchange>) - Constructor for class org.apache.camel.builder.xml.MessageVariableResolver
 
meta() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
method(Object) - Method in class org.apache.camel.builder.BuilderSupport
Returns a method call expression value builder

This method accepts dual parameters.

method(Object, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a method call expression value builder

This method accepts dual parameters.

method(Class<?>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a method call expression value builder
method(Class<?>, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a method call expression value builder
method(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(Object) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(Object, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the bean language which basically means the bean is invoked to determine the expression value.
method(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(Object) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(Object, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an expression using the method(String) - Method in class org.apache.camel.builder.ValueBuilder
Invokes the method with the given name (supports OGNL syntax).
MethodBean - Class in org.apache.camel.component.bean
Represents a Serializable version of a Method
MethodBean() - Constructor for class org.apache.camel.component.bean.MethodBean
 
MethodBean(Method) - Constructor for class org.apache.camel.component.bean.MethodBean
 
MethodCallExpression - Class in org.apache.camel.model.language
To use a Java bean (aka method call) in Camel expressions or predicates.
MethodCallExpression() - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(String, String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(Object) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(Object, String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(Class<?>) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(Class<?>, String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodInfo - Class in org.apache.camel.component.bean
Information about a method to be used for invocation.
MethodInfo(CamelContext, Class<?>, Method, List<ParameterInfo>, List<ParameterInfo>, boolean, boolean) - Constructor for class org.apache.camel.component.bean.MethodInfo
 
MethodInfoCache - Class in org.apache.camel.component.bean
Represents a cache of MethodInfo objects to avoid the expense of introspection for each invocation of a method via a proxy.
MethodInfoCache(CamelContext) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInfoCache(CamelContext, int, int) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInfoCache(CamelContext, Map<Class<?>, BeanInfo>, Map<Method, MethodInfo>) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInvocation - Interface in org.apache.camel.component.bean
Information used by Camel to perform method invocation.
MethodNotFoundException - Exception in org.apache.camel.component.bean
 
MethodNotFoundException(Exchange, Object, String) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
MethodNotFoundException(Exchange, Object, String, String) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
MethodNotFoundException(Exchange, Class<?>, String, boolean) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
MethodNotFoundException(Object, String, Throwable) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
MethodNotFoundException(Class<?>, String, Throwable) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
metricsHealthSnapshotIntervalInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Time in milliseconds to wait between allowing health snapshots to be taken that calculate success and error percentages and affect HystrixCircuitBreaker.isOpen() status.
metricsRollingPercentileBucketSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Maximum number of values stored in each bucket of the rolling percentile.
metricsRollingPercentileEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether percentile metrics should be captured using HystrixRollingPercentile inside HystrixCommandMetrics.
metricsRollingPercentileWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Number of buckets the rolling percentile window is broken into.
metricsRollingPercentileWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Duration of percentile rolling window in milliseconds.
metricsRollingStatisticalWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Number of buckets the rolling statistical window is broken into.
metricsRollingStatisticalWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
This property sets the duration of the statistical rolling window, in milliseconds.
millis() - Method in class org.apache.camel.component.mock.TimeClause.TimeClassUnit
 
mimeMultipart() - Method in class org.apache.camel.builder.DataFormatClause
Uses the MIME Multipart data format
mimeMultipart(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the MIME Multipart data format
mimeMultipart(String, boolean, boolean, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the MIME Multipart data format
mimeMultipart(String, boolean, boolean, String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the MIME Multipart data format
mimeMultipart(boolean, boolean, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the MIME Multipart data format
MimeMultipartDataFormat - Class in org.apache.camel.model.dataformat
The MIME Multipart data format can marshal a Camel message with attachments into a Camel message having a MIME-Multipart message as message body (and no attachments), and vise-versa when unmarshalling.
MimeMultipartDataFormat() - Constructor for class org.apache.camel.model.dataformat.MimeMultipartDataFormat
 
minusValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
minutes() - Method in class org.apache.camel.component.mock.TimeClause.TimeClassUnit
 
mock - Variable in class org.apache.camel.component.mock.AssertionClause
 
MockComponent - Class in org.apache.camel.component.mock
The Mock Component provides mock endpoints for testing.
MockComponent() - Constructor for class org.apache.camel.component.mock.MockComponent
 
MockComponent(CamelContext) - Constructor for class org.apache.camel.component.mock.MockComponent
 
MockEndpoint - Class in org.apache.camel.component.mock
The mock component is used for testing routes and mediation rules using mocks.
MockEndpoint() - Constructor for class org.apache.camel.component.mock.MockEndpoint
 
MockEndpoint(String, Component) - Constructor for class org.apache.camel.component.mock.MockEndpoint
 
mockEndpoints() - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Mock all endpoints.
mockEndpoints(String...) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Mock all endpoints matching the given pattern.
mockEndpointsAndSkip(String...) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Mock all endpoints matching the given pattern, and skips sending to the original endpoint (detour messages).
mode - Variable in class org.apache.camel.builder.XMLTokenExpressionIterator
 
modeAfterConsumer() - Method in class org.apache.camel.model.OnCompletionDefinition
Sets the mode to be after route is done (default due backwards compatible).
modeBeforeConsumer() - Method in class org.apache.camel.model.OnCompletionDefinition
Sets the mode to be before consumer is done.
ModelCamelContext - Interface in org.apache.camel.model
Model level interface for the CamelContext
ModelChannel - Interface in org.apache.camel.model
 
ModelHelper - Class in org.apache.camel.model
Helper for the Camel model classes.
multicast() - Method in class org.apache.camel.model.ProcessorDefinition
Multicast EIP: Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
multicast(AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Multicast EIP: Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
multicast(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Multicast EIP: Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
MulticastDefinition - Class in org.apache.camel.model
Routes the same message to multiple paths either sequentially or in parallel.
MulticastDefinition() - Constructor for class org.apache.camel.model.MulticastDefinition
 
MulticastProcessor - Class in org.apache.camel.processor
Implements the Multicast pattern to send a message exchange to a number of endpoints, each endpoint receiving a copy of the message exchange.
MulticastProcessor(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor.MulticastState - Class in org.apache.camel.processor
 
mvel(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a MVEL expression
mvel(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a MVEL expression
MvelExpression - Class in org.apache.camel.model.language
To use MVEL scripts in Camel expressions or predicates.
MvelExpression() - Constructor for class org.apache.camel.model.language.MvelExpression
 
MvelExpression(String) - Constructor for class org.apache.camel.model.language.MvelExpression
 

N

name() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
name(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the name of the service to use
name(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Name of the parameter.
name(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Name of the parameter.
namespace(String, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers the namespace prefix and URI with the builder so that the prefix can be used in XPath expressions
namespace(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the namespace to use.
namespace(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
Sets the namespace
namespace(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
NamespaceAwareExpression - Class in org.apache.camel.model.language
A useful base class for any expression which may be namespace or XML content aware such as XPathExpression or XQueryExpression
NamespaceAwareExpression() - Constructor for class org.apache.camel.model.language.NamespaceAwareExpression
 
NamespaceAwareExpression(String) - Constructor for class org.apache.camel.model.language.NamespaceAwareExpression
 
NamespacePrefix - Annotation Type in org.apache.camel.language
Creates a namespace prefix for an XPath
Namespaces - Class in org.apache.camel.builder.xml
A helper class for working with namespaces.
Namespaces(Element) - Constructor for class org.apache.camel.builder.xml.Namespaces
Creates a namespaces object from the given XML element
Namespaces(String, String) - Constructor for class org.apache.camel.builder.xml.Namespaces
Creates a namespace context with a single prefix and URI
namespaces(Namespaces) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers namespaces with the builder so that the registered prefixes can be used in XPath expressions
navigate() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
NeverSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the NEVER propagation mode.
NeverSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.NeverSagaProcessor
 
newCachedThreadPool(Object, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newDefaultScheduledThreadPool(Object, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newDefaultThreadPool(Object, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newExchange(Processor) - Method in class org.apache.camel.model.WireTapDefinition
Sends a new Exchange, instead of tapping an existing, using ExchangePattern.InOnly
newExchangeBody(Expression) - Method in class org.apache.camel.model.WireTapDefinition
Sends a new Exchange, instead of tapping an existing, using ExchangePattern.InOnly
newExchangeHeader(String, Expression) - Method in class org.apache.camel.model.WireTapDefinition
Sets a header on the new Exchange, instead of tapping an existing, using ExchangePattern.InOnly.
newExchangeRef(String) - Method in class org.apache.camel.model.WireTapDefinition
Sends a new Exchange, instead of tapping an existing, using ExchangePattern.InOnly
newFixedThreadPool(Object, String, int) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilterFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.CombinedServiceDiscoveryFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.CombinedServiceFilterFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancerFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.HealthyServiceFilterFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.PassThroughServiceFilterFactory
 
newInstance(CamelContext) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscoveryFactory
 
newInstance(String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
newInstance(Class<T>) - Method in class org.apache.camel.impl.DefaultInjector
 
newInstance(CamelContext, String) - Static method in class org.apache.camel.impl.DefaultProducerTemplate
 
newInstance(Exchange) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
newInstance(CamelContext) - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
newInstance(Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
Creates a new instance as a clone of this strategy with the new given original.
newInstance(CamelContext, List<Processor>) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(CamelContext, Processor...) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(CamelContext, List<Processor>, String) - Static method in class org.apache.camel.processor.StepProcessor
 
newInstances(String, Injector, Class<T>) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
newJAXBContext() - Method in class org.apache.camel.impl.DefaultModelJAXBContextFactory
 
newMap() - Method in class org.apache.camel.impl.DefaultHeadersMapFactory
 
newMap(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultHeadersMapFactory
 
newMap() - Method in class org.apache.camel.impl.HashMapHeadersMapFactory
 
newMap(Map<String, Object>) - Method in class org.apache.camel.impl.HashMapHeadersMapFactory
 
newMessageHistory(String, NamedNode, long) - Method in class org.apache.camel.impl.DefaultMessageHistoryFactory
 
newRoutingSlipProcessorForErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
Creates the embedded processor to use when wrapping this routing slip in an error handler.
newScheduledThreadPool(Object, String, ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newScheduledThreadPool(Object, String, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newScheduledThreadPool(Object, String, int) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newSingleThreadExecutor(Object, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newSingleThreadScheduledExecutor(Object, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newThread(String, Runnable) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newThreadPool(Object, String, String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newThreadPool(Object, String, ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
newThreadPool(Object, String, int, int) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
next() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
next() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
next() - Method in class org.apache.camel.processor.ChoiceProcessor
 
next() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
next() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
next() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
next() - Method in class org.apache.camel.processor.MulticastProcessor
 
next() - Method in class org.apache.camel.processor.Pipeline
 
next() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
next() - Method in class org.apache.camel.processor.Resequencer
 
next(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Returns the next routing slip(s).
next() - Method in class org.apache.camel.processor.StreamResequencer
 
next() - Method in class org.apache.camel.processor.TryProcessor
 
next() - Method in class org.apache.camel.processor.WrapProcessor
 
nextToken() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Advances the parser position to the next known SimpleToken in the input.
nextToken(TokenType...) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Advances the parser position to the next known SimpleToken in the input.
nextToken(String, int, boolean, TokenType...) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Create the next token
nextToken(String, int, boolean) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Create the next token
noAutoStartup() - Method in class org.apache.camel.model.RouteDefinition
Disables this route from being auto started when Camel starts.
nodeCounters - Static variable in class org.apache.camel.impl.DefaultNodeIdFactory
 
noDelayer() - Method in class org.apache.camel.model.RouteDefinition
Disable delayer for this route.
nodeResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to XPathConstants.NODE
nodes - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
nodes(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
nodeSetResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to XPathConstants.NODESET
noErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
Creates a disabled error handler for removing the default error handler
NoErrorHandlerBuilder - Class in org.apache.camel.builder
A builder to disable the use of an error handler so that any exceptions are thrown.
NoErrorHandlerBuilder() - Constructor for class org.apache.camel.builder.NoErrorHandlerBuilder
 
noHandleFault() - Method in class org.apache.camel.model.RouteDefinition
Disable handle fault for this route.
noLaterThan(int) - Method in class org.apache.camel.component.mock.TimeClause
 
noMessageHistory() - Method in class org.apache.camel.model.RouteDefinition
Disable message history for this route.
NoMessageIdException - Exception in org.apache.camel.processor.idempotent
An exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.
NoMessageIdException(Exchange, Expression) - Constructor for exception org.apache.camel.processor.idempotent.NoMessageIdException
 
NoOutputDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Base class for definitions which does not support outputs.
NoOutputDefinition() - Constructor for class org.apache.camel.model.NoOutputDefinition
 
NoOutputExpressionNode - Class in org.apache.camel.model
An ExpressionNode which does not support any outputs.
NoOutputExpressionNode() - Constructor for class org.apache.camel.model.NoOutputExpressionNode
 
NoOutputExpressionNode(ExpressionDefinition) - Constructor for class org.apache.camel.model.NoOutputExpressionNode
 
NoOutputExpressionNode(Expression) - Constructor for class org.apache.camel.model.NoOutputExpressionNode
 
NoOutputExpressionNode(Predicate) - Constructor for class org.apache.camel.model.NoOutputExpressionNode
 
normalizedLineSeparator - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
normalizeEndpointUri(String) - Static method in class org.apache.camel.impl.AbstractCamelContext
Normalize uri so we can do endpoint hits with minor mistakes and parameters is not in the same order.
noSpecificLanguageFound(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
noStreamCaching() - Method in class org.apache.camel.model.RouteDefinition
Disable stream caching for this route.
not() - Method in class org.apache.camel.builder.NotifyBuilder
Prepares to append an additional expression using the not operator.
not(Predicate) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return the logical not of the given predicate
not(Predicate) - Method in class org.apache.camel.builder.ValueBuilder
 
not() - Method in class org.apache.camel.builder.ValueBuilder
Negates the built expression.
notify(CamelEvent) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
notify(CamelEvent) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
notify(CamelEvent) - Method in class org.apache.camel.main.MainDurationEventNotifier
 
NotifyBuilder - Class in org.apache.camel.builder
A builder to build an expression based on EventNotifier notifications about Exchange being routed.
NotifyBuilder(CamelContext) - Constructor for class org.apache.camel.builder.NotifyBuilder
Creates a new builder.
noTracing() - Method in class org.apache.camel.model.RouteDefinition
Disable tracing for this route.
NotSupportedSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the NOT_SUPPORTED propagation mode.
NotSupportedSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.NotSupportedSagaProcessor
 
nsmap - Variable in class org.apache.camel.builder.XMLTokenExpressionIterator
 
nullExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the null value
NullExpression - Class in org.apache.camel.language.simple.ast
Represents a null expression.
NullExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.NullExpression
 
nullValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
nullValue - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
numberOfRecordsToRead - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
numberResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to XPathConstants.NUMBER
numericValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 

O

oauth2(String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
oauth2(String, String) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
 
oauthToken(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the OAUTH token for authentication (instead of username/password) when using client lookup
objectModel(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the object model URI to use
ognl(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an OGNL expression
ognl(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an OGNL expression
ognlExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for invoking a method (support OGNL syntax) on the given expression
OgnlExpression - Class in org.apache.camel.model.language
To use OGNL scripts in Camel expressions or predicates.
OgnlExpression() - Constructor for class org.apache.camel.model.language.OgnlExpression
 
OgnlExpression(String) - Constructor for class org.apache.camel.model.language.OgnlExpression
 
oldest(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
OmitFieldEntry() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
OmitFieldEntry(String, String[]) - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
OmitFieldList() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldList
 
OmitFieldsAdapter() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldsAdapter
 
on(CamelContext) - Static method in class org.apache.camel.builder.DefaultFluentProducerTemplate
Create the FluentProducerTemplate by setting the camel context
onAfterProcess(Exchange, Processor, NamedNode, long, Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
onAggregation(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onBeforeProcess(Exchange, Processor, NamedNode, Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
onCamelContextStarted(CamelContext, boolean) - Method in class org.apache.camel.impl.DeferServiceStartupListener
 
onComplete(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onCompletedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a completed message
onCompleteOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
Will only synchronize when the Exchange completed successfully (no errors).
onCompletion(Exchange) - Method in interface org.apache.camel.builder.FlexibleAggregationStrategy.CompletionAwareMixin
 
onCompletion(Exchange) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
 
onCompletion() - Method in class org.apache.camel.builder.RouteBuilder
On completion callback for doing custom routing when the Exchange is complete.
onCompletion() - Method in class org.apache.camel.model.ProcessorDefinition
Adds a onCompletion Synchronization hook that invoke this route as a callback when the Exchange has finished being processed.
onCompletion() - Method in class org.apache.camel.model.RoutesDefinition
Adds an on completion
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
 
onCompletion(String, Exchange, Exchange, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
OnCompletionDefinition - Class in org.apache.camel.model
Route to be executed when normal route processing completes
OnCompletionDefinition() - Constructor for class org.apache.camel.model.OnCompletionDefinition
 
OnCompletionMode - Enum in org.apache.camel.model
 
OnCompletionProcessor - Class in org.apache.camel.processor
Processor implementing onCompletion.
OnCompletionProcessor(CamelContext, Processor, ExecutorService, boolean, boolean, boolean, Predicate, boolean, boolean) - Constructor for class org.apache.camel.processor.OnCompletionProcessor
 
onContextStop(CamelContext) - Method in class org.apache.camel.main.MainLifecycleStrategy
 
onDone(Exchange) - Method in class org.apache.camel.impl.DefaultSubUnitOfWork
 
onDuplicateMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
A strategy method to allow derived classes to overload the behaviour of processing a duplicate message
onEvent(Exchange, CamelEvent.ExchangeEvent, NamedNode) - Method in class org.apache.camel.impl.BreakpointSupport
 
onEvent(Exchange, CamelEvent.ExchangeEvent) - Method in class org.apache.camel.impl.DefaultDebugger
 
onEvent(Exchange, CamelEvent.ExchangeEvent, Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
onEvict(S) - Method in class org.apache.camel.impl.ServicePool
 
onException(Class<? extends Throwable>) - Method in class org.apache.camel.builder.RouteBuilder
Exception clause for catching certain exceptions and handling them.
onException(Class<? extends Throwable>...) - Method in class org.apache.camel.builder.RouteBuilder
Exception clause for catching certain exceptions and handling them.
onException(Class<? extends Throwable>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
onException(Class<? extends Throwable>) - Method in class org.apache.camel.model.ProcessorDefinition
Exception clause for catching certain exceptions and handling them.
onException(Class<? extends Throwable>...) - Method in class org.apache.camel.model.ProcessorDefinition
Exception clause for catching certain exceptions and handling them.
onException(Class<? extends Throwable>) - Method in class org.apache.camel.model.RoutesDefinition
Adds an on exception
OnExceptionDefinition - Class in org.apache.camel.model
Route to be executed when an exception is thrown
OnExceptionDefinition() - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
OnExceptionDefinition(List<Class<? extends Throwable>>) - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
OnExceptionDefinition(Class<? extends Throwable>) - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
onExceptionOccurred - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
onExceptionOccurred(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets a custom Processor to process the Exchange just after an exception was thrown.
onExceptionOccurred(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a processor that should be processed just after an exception occurred.
onExceptionOccurred() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
Gives an optional configured OnExceptionOccurred processor a chance to process just after an exception was thrown while processing the Exchange.
onExceptionOccurredRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a reference to a processor that should be processed just after an exception occurred.
onExceptionProcessor - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
onExchange(Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
 
onExchangeDone(Route, Exchange) - Method in class org.apache.camel.impl.DurationRoutePolicy
 
onExhausted(Exchange) - Method in class org.apache.camel.impl.DefaultSubUnitOfWork
 
onFailedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a failed message
onFailure(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onFailureOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
Will only synchronize when the Exchange ended with failure (exception or FAULT message).
onFallback() - Method in class org.apache.camel.model.HystrixDefinition
The Hystrix fallback route path to execute that does not go over the network.
OnFallbackDefinition - Class in org.apache.camel.model
Route to be executed when Hystrix EIP executes fallback
OnFallbackDefinition() - Constructor for class org.apache.camel.model.OnFallbackDefinition
 
onFallbackViaNetwork() - Method in class org.apache.camel.model.HystrixDefinition
The Hystrix fallback route path to execute that will go over the network.
onHandledFailure(Exception) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
onHit(String) - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
onInit(Route) - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
onInit(Route) - Method in class org.apache.camel.impl.DurationRoutePolicy
 
onInterceptEndpoint(String, Endpoint, MockEndpoint, Producer) - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
Callback when an endpoint was intercepted with the given mock endpoint
onNewExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
Strategy callback when a new ExecutorService have been created.
onNewPredicate(Predicate) - Method in class org.apache.camel.builder.ValueBuilder
A strategy method to allow derived classes to deal with the newly created predicate in different ways
onNewPredicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
onNewValueBuilder(Expression) - Method in class org.apache.camel.builder.ValueBuilder
 
onNewValueBuilder(Expression) - Method in class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
onOptimisticLockFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
onOptimisticLockingFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onPreCompletionAggregation(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onPrepare() - Method in class org.apache.camel.model.MulticastDefinition
Set the Processor to use when preparing the Exchange to be send using a fluent builder.
onPrepare(Processor) - Method in class org.apache.camel.model.MulticastDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepare(Processor) - Method in class org.apache.camel.model.RecipientListDefinition
Uses the Processor when preparing the Exchange to be used send.
onPrepare() - Method in class org.apache.camel.model.RecipientListDefinition
Sets the Processor when preparing the Exchange to be used send using a fluent buidler.
onPrepare(Processor) - Method in class org.apache.camel.model.SplitDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepare(Processor) - Method in class org.apache.camel.model.WireTapDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepare - Variable in class org.apache.camel.processor.MulticastProcessor
 
onPrepareFailure - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
onPrepareFailure(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets a custom Processor to prepare the Exchange before handled by the failure processor / dead letter channel.
onPrepareProcessor - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
onPrepareRef(String) - Method in class org.apache.camel.model.MulticastDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepareRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepareRef(String) - Method in class org.apache.camel.model.SplitDefinition
Uses the Processor when preparing the Exchange to be send.
onPrepareRef(String) - Method in class org.apache.camel.model.WireTapDefinition
Uses the Processor when preparing the Exchange to be send.
onRedelivery - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
onRedelivery(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets a processor that should be processed before a redelivery attempt.
onRedelivery(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a processor that should be processed before a redelivery attempt.
onRedeliveryRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a reference to a processor that should be processed before a redelivery attempt.
onReloadXml(CamelContext, String, InputStream) - Method in class org.apache.camel.impl.ReloadStrategySupport
 
onResume(Route) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
onRollback(Consumer, Endpoint) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
Rollback occurred.
onStart(Route) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
onStart(AggregateProcessor) - Method in interface org.apache.camel.processor.aggregate.AggregateController
Callback when the aggregate processor is started.
onStart(AggregateProcessor) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
onStartingServices(List<Service>) - Method in class org.apache.camel.impl.DefaultRoute
 
onStop(Route) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
onStop(AggregateProcessor) - Method in interface org.apache.camel.processor.aggregate.AggregateController
Callback when the aggregate processor is stopped.
onStop(AggregateProcessor) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
onSuspend(Route) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
onSuspend(Consumer, Endpoint) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
The consumer is to be suspended because it exceeded the limit
onWhen(Predicate) - Method in class org.apache.camel.model.CatchDefinition
Sets an additional predicate that should be true before the onCatch is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.OnCompletionDefinition
Sets an additional predicate that should be true before the onCompletion is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets an additional predicate that should be true before the onException is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.TryDefinition
Sets an additional predicate that should be true before the onCatch is triggered.
operation(ClaimCheckOperation) - Method in class org.apache.camel.model.ClaimCheckDefinition
The claim check operation to use.
optimisticLocking() - Method in class org.apache.camel.model.AggregateDefinition
Turns on using optimistic locking, which requires the aggregationRepository being used, is supporting this by implementing OptimisticLockingAggregationRepository.
optimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.model.AggregateDefinition
Allows to configure retry settings when using optimistic locking.
OptimisticLockRetryPolicy - Class in org.apache.camel.processor.aggregate
Class to control how failed optimistic locks are tried.
OptimisticLockRetryPolicy() - Constructor for class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
OptimisticLockRetryPolicyDefinition - Class in org.apache.camel.model
To configure optimistic locking
OptimisticLockRetryPolicyDefinition() - Constructor for class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
Option(String, String, String) - Constructor for class org.apache.camel.main.MainSupport.Option
 
option(String, Expression) - Method in class org.apache.camel.model.SagaDefinition
 
OptionalIdentifiedDefinition<T extends OptionalIdentifiedDefinition<T>> - Class in org.apache.camel.model
Allows an element to have an optional ID specified
OptionalIdentifiedDefinition() - Constructor for class org.apache.camel.model.OptionalIdentifiedDefinition
 
options - Variable in class org.apache.camel.main.MainSupport
 
or() - Method in class org.apache.camel.builder.NotifyBuilder
Prepares to append an additional expression using the or operator.
or(Predicate, Predicate) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to combine two predicates by a logical OR.
or(List<Predicate>) - Static method in class org.apache.camel.builder.PredicateBuilder
Concat the given predicates into a single predicate, which matches if at least one predicates matches.
or(Predicate...) - Static method in class org.apache.camel.builder.PredicateBuilder
Concat the given predicates into a single predicate, which matches if at least one predicates matches.
order() - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
org.apache.camel.builder - package org.apache.camel.builder
org.apache.camel.builder.xml - package org.apache.camel.builder.xml
Support for XPath based Expressions and Predicates as well as an XSLT processor
org.apache.camel.component.bean - package org.apache.camel.component.bean
The Bean Component which will look up the bean name in the Spring ApplicationContext and use that to dispatch messages to a POJO
org.apache.camel.component.beanclass - package org.apache.camel.component.beanclass
The Class Component for invoking Java classes from Camel
org.apache.camel.component.dataset - package org.apache.camel.component.dataset
A DataSet Endpoint for testing of endpoints using defined DataSets
org.apache.camel.component.mock - package org.apache.camel.component.mock
The Mock Component which is used for testing of routing and mediation rules.
org.apache.camel.component.test - package org.apache.camel.component.test
A Test Endpoint for Pattern Based Testing
org.apache.camel.impl - package org.apache.camel.impl
Default implementation classes for Camel Core
org.apache.camel.impl.cloud - package org.apache.camel.impl.cloud
Base classes and implementation for Camel Cloud
org.apache.camel.impl.cluster - package org.apache.camel.impl.cluster
Base classes and implementation for Camel Cluster
org.apache.camel.impl.transformer - package org.apache.camel.impl.transformer
Transformer implementation classes.
org.apache.camel.language - package org.apache.camel.language
Camel language support such as Bean and Simple language.
org.apache.camel.language.bean - package org.apache.camel.language.bean
Camel Bean language.
org.apache.camel.language.constant - package org.apache.camel.language.constant
Camel Constant language.
org.apache.camel.language.header - package org.apache.camel.language.header
Camel Header language.
org.apache.camel.language.property - package org.apache.camel.language.property
Camel Exchange Property language.
org.apache.camel.language.ref - package org.apache.camel.language.ref
Camel Ref language.
org.apache.camel.language.simple - package org.apache.camel.language.simple
Camel Simple language.
org.apache.camel.language.simple.ast - package org.apache.camel.language.simple.ast
AST for the Camel Simple language.
org.apache.camel.language.simple.types - package org.apache.camel.language.simple.types
Types for the Camel Simple language.
org.apache.camel.language.tokenizer - package org.apache.camel.language.tokenizer
Camel Tokenizer language.
org.apache.camel.language.xpath - package org.apache.camel.language.xpath
Camel XPath language support.
org.apache.camel.main - package org.apache.camel.main
Application level classes that can be used to instantiate camel.
org.apache.camel.model - package org.apache.camel.model
The JAXB POJOs for the XML Configuration of the routing rules.
org.apache.camel.model.cloud - package org.apache.camel.model.cloud
The JAXB POJOs for the remote service call DSL
org.apache.camel.model.config - package org.apache.camel.model.config
The JAXB POJOs for various configurations for the XML Configuration of the routing rules.
org.apache.camel.model.dataformat - package org.apache.camel.model.dataformat
The JAXB POJOs for the Data Formats used to marshal and unmarshal objects to and from streams inside components
org.apache.camel.model.language - package org.apache.camel.model.language
The JAXB POJOs for the Expression and Predicate plugins for the XML Configuration.
org.apache.camel.model.loadbalancer - package org.apache.camel.model.loadbalancer
The JAXB POJOs for the Load Balancer EIP pattern for the XML Configuration.
org.apache.camel.model.rest - package org.apache.camel.model.rest
The JAXB POJOs for the REST DSL
org.apache.camel.model.transformer - package org.apache.camel.model.transformer
The JAXB POJOs for the Transformers used to transform message contents according to declared data types inside components
org.apache.camel.model.validator - package org.apache.camel.model.validator
The JAXB POJOs for the Transformers used to transform message contents according to declared data types inside components
org.apache.camel.processor - package org.apache.camel.processor
A collection of Processor implementations which are used to implement the Enterprise Integration Patterns
org.apache.camel.processor.aggregate - package org.apache.camel.processor.aggregate
Helper classes for the Aggregator pattern.
org.apache.camel.processor.exceptionpolicy - package org.apache.camel.processor.exceptionpolicy
Exception policy startegies for Dead Letter Channel pattern.
org.apache.camel.processor.idempotent - package org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
org.apache.camel.processor.interceptor - package org.apache.camel.processor.interceptor
Helper classes for interceptors.
org.apache.camel.processor.loadbalancer - package org.apache.camel.processor.loadbalancer
Various load balancer processors
org.apache.camel.processor.resequencer - package org.apache.camel.processor.resequencer
Helper classes for the Resequencer pattern.
org.apache.camel.processor.saga - package org.apache.camel.processor.saga
Saga EIP implementation.
org.apache.camel.reifier - package org.apache.camel.reifier
 
org.apache.camel.reifier.loadbalancer - package org.apache.camel.reifier.loadbalancer
 
org.apache.camel.reifier.rest - package org.apache.camel.reifier.rest
 
org.apache.camel.reifier.transformer - package org.apache.camel.reifier.transformer
 
org.apache.camel.reifier.validator - package org.apache.camel.reifier.validator
 
OtherAttributesAware - Interface in org.apache.camel.model
Models can support being configured with any other attributes to shadow existing options to be used for property placeholders.
otherwise() - Method in class org.apache.camel.model.ChoiceDefinition
Sets the otherwise node
OtherwiseDefinition - Class in org.apache.camel.model
Route to be executed when all other choices evaluate to false
OtherwiseDefinition() - Constructor for class org.apache.camel.model.OtherwiseDefinition
 
OUT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
outBody() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message body
outBody(Function<Object, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an outbound message body
outBody(BiFunction<Object, Map<String, Object>, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an outbound message body and headers
outBody(Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message body converted to the expected type
outBody(Class<B>, Function<B, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an outbound message body converted to the expected type
outBody(Class<B>, BiFunction<B, Map<String, Object>, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an outbound message body converted to the expected type and headers
outBody() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an outbound message body
outBody(Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an outbound message body converted to the expected type
outBodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the out messages body
outBodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges outbound message body converted to the given type
outHeader(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message header of the given name
outHeader(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an outbound message header of the given name
outHeaderExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the out header value with the given name

Will fallback and look in properties if not found in headers.

outHeaders() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the outbound headers
outHeaders() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of the outbound headers
outHeadersExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the outbound message headers
outMessage() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message
outMessage(Function<Message, Object>) - Method in class org.apache.camel.builder.ExpressionClause
A functional expression of an outbound message
outMessage() - Method in class org.apache.camel.builder.ExpressionClauseSupport
An expression of an inbound message
outMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the OUT message
outMessageExpression(Function<Message, Object>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a functional expression for the OUT message
output - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
outputAsync - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
OutputDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
A useful base class for output types
OutputDefinition() - Constructor for class org.apache.camel.model.OutputDefinition
 
outputs - Variable in class org.apache.camel.model.OutputDefinition
 
outputType(String) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the output message.
outputType(Class) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the output message by Java class.
OutputTypeDefinition - Class in org.apache.camel.model
Set the expected data type of the output message.
OutputTypeDefinition() - Constructor for class org.apache.camel.model.OutputTypeDefinition
 
outputTypeWithValidate(String) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the output message with content validation enabled.
outputTypeWithValidate(Class) - Method in class org.apache.camel.model.RouteDefinition
Declare the expected data type of the ouput message by Java class with content validation enabled.
outType(Class<?>) - Method in class org.apache.camel.model.rest.RestDefinition
 
overrideProperties - Variable in class org.apache.camel.main.MainSupport
 

P

PackageScanDefinition - Class in org.apache.camel.model
Scans for Java RouteBuilder classes in java packages
PackageScanDefinition() - Constructor for class org.apache.camel.model.PackageScanDefinition
 
parallelAggregate() - Method in class org.apache.camel.model.MulticastDefinition
If enabled then the aggregate method on AggregationStrategy can be called concurrently.
parallelAggregate() - Method in class org.apache.camel.model.RecipientListDefinition
If enabled then the aggregate method on AggregationStrategy can be called concurrently.
parallelAggregate() - Method in class org.apache.camel.model.SplitDefinition
If enabled then the aggregate method on AggregationStrategy can be called concurrently.
parallelProcessing() - Method in class org.apache.camel.model.AggregateDefinition
When aggregated are completed they are being send out of the aggregator.
parallelProcessing(boolean) - Method in class org.apache.camel.model.AggregateDefinition
When aggregated are completed they are being send out of the aggregator.
parallelProcessing() - Method in class org.apache.camel.model.MulticastDefinition
If enabled then sending messages to the multicasts occurs concurrently.
parallelProcessing(boolean) - Method in class org.apache.camel.model.MulticastDefinition
If enabled then sending messages to the multicasts occurs concurrently.
parallelProcessing() - Method in class org.apache.camel.model.OnCompletionDefinition
If enabled then the on completion process will run asynchronously by a separate thread from a thread pool.
parallelProcessing(boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
If enabled then the on completion process will run asynchronously by a separate thread from a thread pool.
parallelProcessing() - Method in class org.apache.camel.model.RecipientListDefinition
If enabled then sending messages to the recipients occurs concurrently.
parallelProcessing(boolean) - Method in class org.apache.camel.model.RecipientListDefinition
If enabled then sending messages to the recipients occurs concurrently.
parallelProcessing() - Method in class org.apache.camel.model.SplitDefinition
If enabled then processing each splitted messages occurs concurrently.
parallelProcessing(boolean) - Method in class org.apache.camel.model.SplitDefinition
If enabled then processing each splitted messages occurs concurrently.
param() - Method in class org.apache.camel.model.rest.RestDefinition
 
param(RestOperationParamDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
 
param(VerbDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
 
ParameterBindingException - Exception in org.apache.camel.component.bean
 
ParameterBindingException(Throwable, Method, int, Class<?>, Object) - Constructor for exception org.apache.camel.component.bean.ParameterBindingException
 
ParameterInfo - Class in org.apache.camel.component.bean
Parameter information to be used for method invocation.
ParameterInfo(int, Class<?>, Annotation[], Expression) - Constructor for class org.apache.camel.component.bean.ParameterInfo
 
ParameterMappingStrategy - Interface in org.apache.camel.component.bean
A strategy for creating a default parameter expression for a given type
ParameterOption(String, String, String, String) - Constructor for class org.apache.camel.main.MainSupport.ParameterOption
 
params(List<RestOperationParamDefinition>) - Method in class org.apache.camel.model.rest.RestDefinition
 
parse(String) - Static method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
parseAndCreateAstModel() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
parseArguments(String[]) - Method in class org.apache.camel.main.MainSupport
Parses the command line arguments.
parseExpression() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
parsePredicate() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
parseSimpleOrFallbackToConstantExpression(String, CamelContext) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns Simple expression or fallback to Constant expression if expression str is not Simple expression.
parseTokensAndCreateNodes() - Method in class org.apache.camel.language.simple.SimplePredicateParser
Parses the tokens and crates the AST nodes.
passThrough() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
passThroughFilter() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
passThroughFilter() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
PassThroughServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
PassThroughServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.PassThroughServiceCallServiceFilterConfiguration
 
PassThroughServiceCallServiceFilterConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.PassThroughServiceCallServiceFilterConfiguration
 
PassThroughServiceFilter - Class in org.apache.camel.impl.cloud
 
PassThroughServiceFilter() - Constructor for class org.apache.camel.impl.cloud.PassThroughServiceFilter
 
PassThroughServiceFilterFactory - Class in org.apache.camel.impl.cloud
 
PassThroughServiceFilterFactory() - Constructor for class org.apache.camel.impl.cloud.PassThroughServiceFilterFactory
 
password(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the password to be used for basic authentication
password(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The password to use for basic authentication.
password(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the password for authentication when using client lookup
password(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
Sets the password
password(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
patch() - Method in class org.apache.camel.model.rest.RestDefinition
 
patch(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
PatchVerbDefinition - Class in org.apache.camel.model.rest
Rest PATCH command
PatchVerbDefinition() - Constructor for class org.apache.camel.model.rest.PatchVerbDefinition
 
path - Variable in class org.apache.camel.builder.XMLTokenExpressionIterator
 
path(String) - Method in class org.apache.camel.model.rest.RestDefinition
To set the base path of this REST service
pattern(ExchangePattern) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets the optional ExchangePattern used to invoke this endpoint
pattern(ExchangePattern) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the optional ExchangePattern used to invoke this endpoint
pattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
pattern(ExchangePattern) - Method in class org.apache.camel.model.ToDynamicDefinition
Sets the optional ExchangePattern used to invoke this endpoint
pattern - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
pattern - Variable in class org.apache.camel.processor.SendProcessor
 
performAssertions(Exchange, Exchange) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
performAssertions(Exchange, Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
Performs the assertions on the incoming exchange.
performMaxDurationAction() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
performMaxMessagesAction() - Method in class org.apache.camel.impl.DurationRoutePolicy
 
pgp(String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the PGP data format
pgp(String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the PGP data format
pgp(String, String, String, boolean, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the PGP data format
PGPDataFormat - Class in org.apache.camel.model.dataformat
PGP data format is used for encrypting and decrypting of messages using Java Cryptographic Extension and PGP.
PGPDataFormat() - Constructor for class org.apache.camel.model.dataformat.PGPDataFormat
 
pick(Expression) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Set an expression to extract the element to be aggregated from the incoming Exchange.
pipeline() - Method in class org.apache.camel.model.ProcessorDefinition
Pipes and Filters EIP: Creates a Pipeline so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
pipeline(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Pipes and Filters EIP: Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
pipeline(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Pipes and Filters EIP: Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
pipeline(Collection<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Pipes and Filters EIP: Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
Pipeline - Class in org.apache.camel.processor
Creates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchanges
Pipeline(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.Pipeline
 
PipelineDefinition - Class in org.apache.camel.model
Routes the message to a sequence of processors.
PipelineDefinition() - Constructor for class org.apache.camel.model.PipelineDefinition
 
PipelineHelper - Class in org.apache.camel.processor
Helper for processing Exchange in a pipeline.
placeholder(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a placeholder for the given option

Requires using the org.apache.camel.component.properties.PropertiesComponent

PLACEHOLDER_QNAME - Static variable in class org.apache.camel.model.Constants
 
PojoMessageInvocationHandler - Class in org.apache.camel.component.bean
Special InvocationHandler for methods that have only one parameter.
PojoMessageInvocationHandler(Endpoint, Producer) - Constructor for class org.apache.camel.component.bean.PojoMessageInvocationHandler
 
PojoProxyHelper - Class in org.apache.camel.component.bean
Create a dynamic proxy for a given interface and endpoint that sends the parameter object to the endpoint and optionally receives a reply.
policy(Policy) - Method in class org.apache.camel.model.ProcessorDefinition
Apply a Policy.
policy(String) - Method in class org.apache.camel.model.ProcessorDefinition
Apply a Policy.
PolicyDefinition - Class in org.apache.camel.model
Defines a policy the route will use
PolicyDefinition() - Constructor for class org.apache.camel.model.PolicyDefinition
 
PolicyDefinition(Policy) - Constructor for class org.apache.camel.model.PolicyDefinition
 
pollEnrich(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long, String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long, AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long, String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(Expression, long, String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich() - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
PollEnrichDefinition - Class in org.apache.camel.model
Enriches messages with data polled from a secondary resource
PollEnrichDefinition() - Constructor for class org.apache.camel.model.PollEnrichDefinition
 
PollEnrichDefinition(AggregationStrategy, long) - Constructor for class org.apache.camel.model.PollEnrichDefinition
 
PollEnricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
PollEnricher(Expression, long) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
pollEnrichWith(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder using a PollingConsumer to poll the endpoint.
pollEnrichWith(String, long) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder using a PollingConsumer to poll the endpoint.
pollEnrichWith(String, long, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri and with an aggregation strategy created using a fluent builder using a PollingConsumer to poll the endpoint.
poolSize(int) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
poolSize(Integer) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
poolSize(int) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
poolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
poolSize(int) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the core pool size
pop() - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
popRouteContext() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
popRouteContext() - Method in class org.apache.camel.impl.MDCUnitOfWork
 
populateDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
Allows derived classes to customize a default set of properties
populateDefaultNamespaces(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
Populate a number of standard prefixes if they are not already there
populateMessage(Exchange, long) - Method in interface org.apache.camel.component.dataset.DataSet
Populates a message exchange when using the DataSet as a source of messages
populateMessage(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
populateRests() - Method in class org.apache.camel.builder.RouteBuilder
 
populateRoutes() - Method in class org.apache.camel.builder.RouteBuilder
 
populateTransformers() - Method in class org.apache.camel.builder.RouteBuilder
 
populateValidators() - Method in class org.apache.camel.builder.RouteBuilder
 
port() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
port(int) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify the port number to use for the REST service
port(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify the port number to use for the REST service
portHeader(String) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
The header that holds the service port information, default ServiceCallConstants.SERVICE_PORT
portName(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets Port Name to use for DNS/SNDSRV lookup.
portProtocol(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets Port Protocol to use for DNS/SNDSRV lookup.
post() - Method in class org.apache.camel.model.rest.RestDefinition
 
post(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
post() - Method in class org.apache.camel.model.rest.VerbDefinition
 
post(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
postInitChannel(ProcessorDefinition<?>, RouteContext) - Method in interface org.apache.camel.model.ModelChannel
Post initializes the channel.
postInitChannel(ProcessorDefinition<?>, RouteContext) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
postProcess(Exchange) - Method in class org.apache.camel.processor.Resequencer
 
postProcessAfterInitialization(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
postProcessCamelContext(CamelContext) - Method in class org.apache.camel.main.MainSupport
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
postProcessFactoryParameters(CamelContext, Map<String, Object>) - Method in class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
 
PostVerbDefinition - Class in org.apache.camel.model.rest
Rest POST command
PostVerbDefinition() - Constructor for class org.apache.camel.model.rest.PostVerbDefinition
 
preCheckPoll(Exchange) - Method in class org.apache.camel.processor.PollEnricher
Strategy to pre check polling.
preComplete(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
preCreateProcessor() - Method in class org.apache.camel.model.ExpressionNode
 
preCreateProcessor() - Method in class org.apache.camel.model.HystrixDefinition
 
preCreateProcessor() - Method in class org.apache.camel.model.ProcessorDefinition
Strategy to execute any custom logic before the Processor is created.
preCreateProcessor() - Method in class org.apache.camel.model.TryDefinition
 
preCreateProcessor() - Method in class org.apache.camel.reifier.ProcessorReifier
Strategy to execute any custom logic before the Processor is created.
predecessor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
predecessor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate predecessor of the given element in this sequence or null if no predecessor exists.
predecessor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate predecessor of o2.
predicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause
Adds the given predicate to this assertion clause
predicate() - Method in class org.apache.camel.component.mock.AssertionClause
Adds the given predicate to this assertion clause
predicate(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Predicate.
PredicateBuilder - Class in org.apache.camel.builder
A helper class for working with predicates
PredicateClause<T> - Class in org.apache.camel.builder
 
PredicateClause(T) - Constructor for class org.apache.camel.builder.PredicateClause
 
PredicateValidatorDefinition - Class in org.apache.camel.model.validator
Represents a predicate Validator which leverages expression or predicates to perform content validation.
PredicateValidatorDefinition() - Constructor for class org.apache.camel.model.validator.PredicateValidatorDefinition
 
PredicateValueBuilder(Expression) - Constructor for class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
prepare(ModelCamelContext) - Method in class org.apache.camel.model.RouteDefinition
Prepares the route definition to be ready to be added to CamelContext
prepareBlocks() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Prepares blocks, such as functions, single or double quoted texts.
prepareExchange(Exchange, int) - Method in class org.apache.camel.processor.LoopProcessor
Prepares the exchange for the next iteration
prepareExchange(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
Prepares the Exchange to send as onCompletion.
prepareExchangeAfterFailure(Exchange, boolean, boolean, boolean) - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForContinue(Exchange, boolean) - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForFailover(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Prepares the exchange for failover
prepareExchangeForRedelivery() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForRoutingSlip(Exchange, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
prepareRoute(ModelCamelContext, RouteDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Prepares the route.
prepareRoute(ModelCamelContext, RouteDefinition, List<OnExceptionDefinition>, List<InterceptDefinition>, List<InterceptFromDefinition>, List<InterceptSendToEndpointDefinition>, List<OnCompletionDefinition>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Prepares the route which supports context scoped features such as onException, interceptors and onCompletions

This method does not mark the route as prepared afterwards.

prepareRouteForInit(RouteDefinition, List<ProcessorDefinition<?>>, List<ProcessorDefinition<?>>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
 
prepareSharedUnitOfWork(Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Prepares the exchange for participating in a shared unit of work

This ensures a child exchange can access its parent UnitOfWork when it participate in a shared unit of work.

prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.WireTapProcessor
 
prepareUnaryExpressions() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Prepares unary expressions.
preparingShutdown - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
prepend(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Prepends the String evaluations of the two expressions together
prepend(Object) - Method in class org.apache.camel.builder.ValueBuilder
Prepends the string evaluation of this expression with the given value
previousIndex - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
proceed(AsyncCallback) - Method in interface org.apache.camel.component.bean.MethodInvocation
Proceed and invokes the method.
process(Exchange) - Method in class org.apache.camel.builder.ProcessClause
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
process(Exchange) - Method in class org.apache.camel.component.bean.BeanProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.bean.BeanProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.bean.BeanProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.cloud.DefaultServiceCallProcessor
 
process(String, ServiceLoadBalancerFunction<T>) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
process(AsyncProcessor, Exchange) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
Calls the async version of the processor's process method and waits for it to complete before returning.
process(Exchange) - Method in class org.apache.camel.impl.DeferProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.DeferProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
process(Processor) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds the custom processor to this destination which could be a final destination, or could be a transformation in a pipeline
process(String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds the custom processor reference to this destination which could be a final destination, or could be a transformation in a pipeline
process() - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds the custom processor using a fluent builder to this destination which could be a final destination, or could be a transformation in a pipeline
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CamelInternalProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CatchProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ChoiceProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Enricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.EventNotifierProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FilterProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FinallyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
process(Exchange) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
Process invoked by the interceptor
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LogProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LoopProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MulticastProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Pipeline
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.PollEnricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
 
process(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Process the exchange using redelivery error handling.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Resequencer
Enqueues an exchange for later batch processing.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RollbackProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RoutingSlip
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.MandatorySagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.NeverSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.NotSupportedSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.RequiredSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.RequiresNewSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.SupportsSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SamplingThrottler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ScriptProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
process(Exchange, AsyncProcessor, Processor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Synchronous API
process(Exchange, AsyncCallback, AsyncProcessor, Processor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Asynchronous API
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SortProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Splitter
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StepProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StopProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StreamResequencer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThreadsProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Throttler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TransformProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TryProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.WireTapProcessor
 
processAsync(Exchange) - Method in class org.apache.camel.component.bean.BeanProcessor
 
processAsync(Exchange) - Method in class org.apache.camel.impl.DeferProducer
 
processAsync(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
processAsync(Exchange) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
processAsync(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
processAsynchronously(Exchange, AsyncCallback, Throttler.ThrottlingState) - Method in class org.apache.camel.processor.Throttler
Delegate blocking on the DelayQueue to an asyncExecutor.
ProcessClause<T> - Class in org.apache.camel.builder
 
ProcessClause(T) - Constructor for class org.apache.camel.builder.ProcessClause
 
ProcessDefinition - Class in org.apache.camel.model
Calls a Camel processor
ProcessDefinition() - Constructor for class org.apache.camel.model.ProcessDefinition
 
ProcessDefinition(Processor) - Constructor for class org.apache.camel.model.ProcessDefinition
 
processDelay(Exchange, AsyncCallback, long) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
processExchange(Exchange) - Method in class org.apache.camel.processor.Resequencer
Strategy Method to process an exchange in the batch.
processExchange(Endpoint, Exchange, Exchange, AsyncCallback, RoutingSlip.RoutingSlipIterator) - Method in class org.apache.camel.processor.RoutingSlip
 
processOption(String, LinkedList<String>) - Method in class org.apache.camel.main.MainSupport.Option
 
ProcessorDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Base class for processor types that most XML types extend.
ProcessorDefinition() - Constructor for class org.apache.camel.model.ProcessorDefinition
 
ProcessorDefinitionHelper - Class in org.apache.camel.model
Helper class for ProcessorDefinition and the other model classes.
ProcessorExchangePair - Interface in org.apache.camel.processor
Exchange pair to be executed by MulticastProcessor.
ProcessorReifier<T extends ProcessorDefinition<?>> - Class in org.apache.camel.reifier
 
ProcessorReifier(T) - Constructor for class org.apache.camel.reifier.ProcessorReifier
 
ProcessorTransformer - Class in org.apache.camel.impl.transformer
A Transformer implementation which leverages Processor to perform transformation.
ProcessorTransformer(CamelContext) - Constructor for class org.apache.camel.impl.transformer.ProcessorTransformer
 
producer - Variable in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
 
producer - Variable in class org.apache.camel.processor.SendProcessor
 
producerApiDoc(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
producerCache - Variable in class org.apache.camel.processor.RoutingSlip
 
producerCache - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
producerCache - Variable in class org.apache.camel.processor.SendProcessor
 
producerComponent(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific Camel rest component (producer)
produces(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
propagateException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagation(SagaPropagation) - Method in class org.apache.camel.model.SagaDefinition
 
propagation(SagaPropagation) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
PROPAGATION_REQUIRED - Static variable in class org.apache.camel.model.TransactedDefinition
 
propertiesComponentExpression(String, String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
property(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
Adds a custom property to use.
property(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
Adds a custom property to use.
property(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
Adds a custom property to use.
property(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
Adds a custom property to use.
property(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
Adds a custom property to use.
PropertyDefinition - Class in org.apache.camel.model
A key value pair
PropertyDefinition() - Constructor for class org.apache.camel.model.PropertyDefinition
 
propertyInject(String, Class<T>) - Method in class org.apache.camel.builder.RouteBuilder
Injects a property placeholder value with the given key converted to the given type.
propertyOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value of exchange with the given name invoking methods defined in a simple OGNL notation
propertyPlaceholderLocations - Variable in class org.apache.camel.main.MainSupport
 
proto(String) - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
The transport protocol of the desired service.
protobuf() - Method in class org.apache.camel.builder.DataFormatClause
Uses the protobuf data format
protobuf(Object) - Method in class org.apache.camel.builder.DataFormatClause
 
protobuf(Object, String) - Method in class org.apache.camel.builder.DataFormatClause
 
protobuf(String) - Method in class org.apache.camel.builder.DataFormatClause
 
protobuf(String, String) - Method in class org.apache.camel.builder.DataFormatClause
 
ProtobufDataFormat - Class in org.apache.camel.model.dataformat
The Protobuf data format is used for serializing between Java objects and the Google Protobuf protocol.
ProtobufDataFormat() - Constructor for class org.apache.camel.model.dataformat.ProtobufDataFormat
 
ProtobufDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.ProtobufDataFormat
 
ProtobufDataFormat(String, String) - Constructor for class org.apache.camel.model.dataformat.ProtobufDataFormat
 
ProxyBuilder - Class in org.apache.camel.builder
A build to create Camel proxies.
ProxyBuilder(CamelContext) - Constructor for class org.apache.camel.builder.ProxyBuilder
 
ProxyHelper - Class in org.apache.camel.component.bean
A helper class for creating proxies which delegate to Camel
purge() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
Purges the cache
purge() - Method in class org.apache.camel.impl.DefaultConsumerCache
Purges this cache
purge() - Method in class org.apache.camel.impl.DefaultProducerCache
Purges this cache
push(Exchange) - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.MDCUnitOfWork
 
put(K, V) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
put() - Method in class org.apache.camel.model.rest.RestDefinition
 
put(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
put() - Method in class org.apache.camel.model.rest.VerbDefinition
 
put(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
PutVerbDefinition - Class in org.apache.camel.model.rest
Rest PUT command
PutVerbDefinition() - Constructor for class org.apache.camel.model.rest.PutVerbDefinition
 

Q

QueueLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)
QueueLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
queueSizeRejectionThreshold(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Queue size rejection threshold is an artificial max size at which rejections will occur even if maxQueueSize has not been reached.
quoteEmbeddedNodes() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
quoteEmbeddedNodes() - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Whether to quote embedded nodes.

R

random() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses random load balancer
randomBackOff() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
randomBackOff(boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
Enables random backoff
randomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
randomExpression(int) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a random number between 0 and max (exclusive)
randomExpression(int, int) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a random number between min and max (exclusive)
randomExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a random number between min and max (exclusive)
RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the random load balancing policy
RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
RandomLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Random load balancer The random load balancer selects a random endpoint for each exchange.
RandomLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
 
randomNumberGenerator - Static variable in class org.apache.camel.processor.RedeliveryPolicy
 
RandomServiceChooser - Class in org.apache.camel.impl.cloud
 
RandomServiceChooser() - Constructor for class org.apache.camel.impl.cloud.RandomServiceChooser
 
ratios - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
readExternal(ObjectInput) - Method in class org.apache.camel.component.bean.BeanInvocation
 
readTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Read timeout for OkHttpClient
reason() - Method in class org.apache.camel.impl.SupervisingRouteController.FilterResult
 
receive(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerCache
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerCache
 
receive(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerCache
 
receiveNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
recipientList(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients.
recipientList(Expression, String) - Method in class org.apache.camel.model.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
recipientList(String) - Method in class org.apache.camel.model.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
recipientList() - Method in class org.apache.camel.model.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
RecipientList - Class in org.apache.camel.processor
Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
RecipientList(CamelContext) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, String) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, Expression) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientListDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Routes messages to a number of dynamically specified recipients (dynamic to)
RecipientListDefinition() - Constructor for class org.apache.camel.model.RecipientListDefinition
 
RecipientListDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.RecipientListDefinition
 
RecipientListDefinition(Expression) - Constructor for class org.apache.camel.model.RecipientListDefinition
 
RecipientListProcessor - Class in org.apache.camel.processor
Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
reconnectBaseSleepTime(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
reconnectMaxRetries(int) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
reconnectMaxSleepTime(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
redeliver() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
redeliveryDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
redeliveryDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the initial redelivery delay
redeliveryDelay(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the initial redelivery delay (supports property placeholders)
redeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the initial redelivery delay
redeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the initial redelivery delay (supports property placeholders)
redeliveryDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
redeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
redeliveryEnabled - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
RedeliveryErrorHandler - Class in org.apache.camel.processor
Base redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.
RedeliveryErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, Processor, String, boolean, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler
 
RedeliveryErrorHandler.RedeliveryState - Class in org.apache.camel.processor
Contains the current redelivery state
redeliveryPolicy - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
redeliveryPolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
RedeliveryPolicy - Class in org.apache.camel.processor
The policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead Letter Channel
RedeliveryPolicy() - Constructor for class org.apache.camel.processor.RedeliveryPolicy
 
RedeliveryPolicyDefinition - Class in org.apache.camel.model
To configure re-delivery for error handling
RedeliveryPolicyDefinition() - Constructor for class org.apache.camel.model.RedeliveryPolicyDefinition
 
redeliveryPolicyRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a reference to a RedeliveryPolicy to lookup in the Registry to be used.
redeliveryProcessor - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
redeliverySleepCounter - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
RedeliveryState(Exchange, AsyncCallback) - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
ref(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Ref expression
ref(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Expression by looking up existing Expression from the Registry
ref(Object) - Static method in class org.apache.camel.language.ref.RefLanguage
 
ref - Variable in class org.apache.camel.model.PolicyDefinition
 
ref(String) - Method in class org.apache.camel.model.PolicyDefinition
Sets a reference to use for lookup the policy in the registry.
ref - Variable in class org.apache.camel.model.TransactedDefinition
 
ref(String) - Method in class org.apache.camel.model.TransactedDefinition
Sets a reference to use for lookup the policy in the registry.
refExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for lookup a bean in the Registry
RefExpression - Class in org.apache.camel.model.language
Reference to an existing Camel expression or predicate, which is looked up from the Camel registry.
RefExpression() - Constructor for class org.apache.camel.model.language.RefExpression
 
RefExpression(String) - Constructor for class org.apache.camel.model.language.RefExpression
 
RefLanguage - Class in org.apache.camel.language.ref
A language for referred expressions or predicates.
RefLanguage() - Constructor for class org.apache.camel.language.ref.RefLanguage
 
regex(Expression, String) - Static method in class org.apache.camel.builder.PredicateBuilder
Returns a predicate which is true if the expression matches the given regular expression
regex(Expression, Pattern) - Static method in class org.apache.camel.builder.PredicateBuilder
Returns a predicate which is true if the expression matches the given regular expression
regex(String) - Method in class org.apache.camel.builder.ValueBuilder
Creates a predicate which is true if this expression matches the given regular expression
regexReplaceAll(Expression, String, String) - Static method in class org.apache.camel.builder.Builder
Returns an expression that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.builder.Builder
Returns an expression that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns an expression value builder that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, Expression) - Method in class org.apache.camel.builder.BuilderSupport
Returns an expression value builder that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Transforms the expression into a String then performs the regex replaceAll to transform the String and return the result
regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Transforms the expression into a String then performs the regex replaceAll to transform the String and return the result
regexReplaceAll(String, String) - Method in class org.apache.camel.builder.ValueBuilder
Replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(String, Expression) - Method in class org.apache.camel.builder.ValueBuilder
Replaces all occurrences of the regular expression with the given replacement
regexTokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
Tokenizes the string conversion of this expression using the given regular expression
regexTokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given regex
registerEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
 
registerThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
registry - Variable in class org.apache.camel.main.Main
 
RegistryBean - Class in org.apache.camel.component.bean
An implementation of a BeanHolder which will look up a bean from the registry and act as a cache of its metadata
RegistryBean(CamelContext, String) - Constructor for class org.apache.camel.component.bean.RegistryBean
 
RegistryBean(Registry, CamelContext, String) - Constructor for class org.apache.camel.component.bean.RegistryBean
 
registryExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the Registry
reifier(LoadBalancerDefinition) - Static method in class org.apache.camel.reifier.loadbalancer.LoadBalancerReifier
 
reifier(ProcessorDefinition<?>) - Static method in class org.apache.camel.reifier.ProcessorReifier
 
reifier(TransformerDefinition) - Static method in class org.apache.camel.reifier.transformer.TransformerReifier
 
reifier(ValidatorDefinition) - Static method in class org.apache.camel.reifier.validator.ValidatorReifier
 
rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.builder.ThreadPoolBuilder
 
rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
 
rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the handler for tasks which cannot be executed by the thread pool.
rejectExecution(boolean) - Method in class org.apache.camel.model.ThrottleDefinition
Whether or not throttler throws the ThrottlerRejectedExecutionException when the exchange exceeds the request limit

Is by default false

rejectOld() - Method in class org.apache.camel.model.ResequenceDefinition
Sets the rejectOld flag to throw an error when a message older than the last delivered message is processed
release(Endpoint, S) - Method in class org.apache.camel.impl.ServicePool
Releases the service back to the pool
releasePollingConsumer(Endpoint, PollingConsumer) - Method in class org.apache.camel.impl.DefaultConsumerCache
Releases an acquired producer back after usage.
releaseProducer(Endpoint, AsyncProducer) - Method in class org.apache.camel.impl.DefaultProducerCache
Releases an acquired producer back after usage.
reloadStrategy - Variable in class org.apache.camel.main.MainSupport
 
ReloadStrategySupport - Class in org.apache.camel.impl
Base class for implementing custom ReloadStrategy SPI plugins.
ReloadStrategySupport() - Constructor for class org.apache.camel.impl.ReloadStrategySupport
 
remove() - Method in class org.apache.camel.builder.AdviceWithBuilder
Removes the matched node(s)
remove(Object) - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
remove(String) - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
remove(Exchange) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
remove(Exchange, String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
remove(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
removeAggregationStrategyFromExchange(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Removes the associated AggregationStrategy from the Exchange which must be done after use.
removeAllBreakpoints() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeAllOnCompletionDefinition(ProcessorDefinition<?>) - Method in class org.apache.camel.model.OnCompletionDefinition
Removes all existing OnCompletionDefinition from the definition.
removeBreakpoint(Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
removeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeById(RouteDefinition, String, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
removeByToString(RouteDefinition, String, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
removeByToUri(RouteDefinition, String, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
removeByType(RouteDefinition, Class<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
removeComponent(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeEndpoint(Endpoint) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeEndpoints(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeEventNotifier(EventNotifier) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
removeFilter(PackageScanFilter) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
removeHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the header on the IN message
RemoveHeaderDefinition - Class in org.apache.camel.model
Removes a named header from the message
RemoveHeaderDefinition() - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
 
RemoveHeaderDefinition(String) - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
 
RemoveHeaderProcessor - Class in org.apache.camel.processor
A processor which removes the header from the IN or OUT message
RemoveHeaderProcessor(String) - Constructor for class org.apache.camel.processor.RemoveHeaderProcessor
 
removeHeaders(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the headers on the IN message
removeHeaders(String, String...) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the headers on the IN message
RemoveHeadersDefinition - Class in org.apache.camel.model
Removes message headers whose name matches a specified pattern
RemoveHeadersDefinition() - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
 
RemoveHeadersDefinition(String) - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
 
RemoveHeadersDefinition(String, String...) - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
 
RemoveHeadersProcessor - Class in org.apache.camel.processor
A processor which removes one ore more headers from the IN or OUT message
RemoveHeadersProcessor(String, String[]) - Constructor for class org.apache.camel.processor.RemoveHeadersProcessor
 
removeMainListener(MainListener) - Method in class org.apache.camel.main.MainSupport
Removes the MainListener
removeMessageBodyOnBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeMessageHeaderOnBreakpoint(String, String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeOnExceptionList(String) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
removeOnExceptionList(String) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
Remove the OnExceptionList by look up the route id from the ErrorHandlerBuilder internal map
removeOnFailure(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets whether to remove or keep the key on failure.
removeProcessor(AsyncProcessor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Removes the given processor from the load balancer
removeProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
removeProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
removeProperties(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the properties in the exchange
removeProperties(String, String...) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the properties in the exchange
RemovePropertiesDefinition - Class in org.apache.camel.model
Removes message exchange properties whose name matches a specified pattern
RemovePropertiesDefinition() - Constructor for class org.apache.camel.model.RemovePropertiesDefinition
 
RemovePropertiesDefinition(String) - Constructor for class org.apache.camel.model.RemovePropertiesDefinition
 
RemovePropertiesDefinition(String, String...) - Constructor for class org.apache.camel.model.RemovePropertiesDefinition
 
RemovePropertiesProcessor - Class in org.apache.camel.processor
A processor which removes one ore more properties from the exchange
RemovePropertiesProcessor(String, String[]) - Constructor for class org.apache.camel.processor.RemovePropertiesProcessor
 
removeProperty(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which removes the exchange property
RemovePropertyDefinition - Class in org.apache.camel.model
Removes a named property from the message exchange
RemovePropertyDefinition() - Constructor for class org.apache.camel.model.RemovePropertyDefinition
 
RemovePropertyDefinition(String) - Constructor for class org.apache.camel.model.RemovePropertyDefinition
 
RemovePropertyProcessor - Class in org.apache.camel.processor
A processor which removes the property from the exchange
RemovePropertyProcessor(String) - Constructor for class org.apache.camel.processor.RemovePropertyProcessor
 
removeRestService(Consumer) - Method in class org.apache.camel.impl.DefaultRestRegistry
 
removeRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeRoute(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
removeRouteDefinition(String) - Method in class org.apache.camel.impl.AbstractCamelContext
Removes the route definition with the given key.
removeRouteDefinition(RouteDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeRouteDefinition(RouteDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Removes a route definition from the context - stopping any previously running routes if any of them are actively running
removeRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Removes a collection of route definitions from the context - stopping any previously running routes if any of them are actively running
removeServer(Predicate<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
Remove an existing server from the list of known servers.
removeServer(Predicate<ServiceDefinition>) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
Remove an existing server from the list of known servers.
removeService(Object) - Method in class org.apache.camel.impl.AbstractCamelContext
 
removeSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
replace() - Method in class org.apache.camel.builder.AdviceWithBuilder
Replaces the matched node(s) with the following nodes.
replaceById(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
replaceByToString(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
replaceByToUri(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
replaceByType(RouteDefinition, Class<?>, ProcessorDefinition<?>, boolean, boolean, int, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
replaceFrom(RouteDefinition, Endpoint) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
replaceFromWith(String) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Replaces the route from endpoint with a new uri
replaceFromWith(Endpoint) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Replaces the route from endpoint with a new endpoint
replaceFromWith(RouteDefinition, String) - Static method in class org.apache.camel.builder.AdviceWithTasks
 
reporter - Variable in class org.apache.camel.component.mock.MockEndpoint
 
request() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
request(Class<T>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
request(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
request(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestLogEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Whether HystrixCommand execution and events should be logged to HystrixRequestLog.
required(Boolean) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Whether the parameter is required
RequiredSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the REQUIRED propagation mode.
RequiredSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.RequiredSagaProcessor
 
RequiresNewSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the REQUIRES_NEW propagation mode.
RequiresNewSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.RequiresNewSagaProcessor
 
resequence() - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a resequencer allowing you to reorganize messages based on some comparator.
resequence(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a resequencer allowing you to reorganize messages based on some comparator.
ResequenceDefinition - Class in org.apache.camel.model
Resequences (re-order) messages based on an expression
ResequenceDefinition() - Constructor for class org.apache.camel.model.ResequenceDefinition
 
ResequenceDefinition(Expression) - Constructor for class org.apache.camel.model.ResequenceDefinition
 
Resequencer - Class in org.apache.camel.processor
An implementation of the Resequencer which can reorder messages within a batch.
Resequencer(CamelContext, Processor, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(CamelContext, Processor, Expression, boolean, boolean) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(CamelContext, Processor, Set<Exchange>, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
ResequencerConfig - Class in org.apache.camel.model.config
 
ResequencerConfig() - Constructor for class org.apache.camel.model.config.ResequencerConfig
 
ResequencerEngine<E> - Class in org.apache.camel.processor.resequencer
Resequences elements based on a given SequenceElementComparator.
ResequencerEngine(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.ResequencerEngine
Creates a new resequencer instance with a default timeout of 2000 milliseconds.
reset() - Method in class org.apache.camel.builder.NotifyBuilder
Resets the notifier.
reset() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
reset() - Method in class org.apache.camel.component.mock.MockEndpoint
 
reset(CamelContext, String) - Static method in class org.apache.camel.impl.DefaultRouteError
 
reset() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
reset() - Method in class org.apache.camel.impl.FileStateRepository
Resets and clears the store to force it to reload from file
reset() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Reset the counters
reset() - Method in class org.apache.camel.processor.ChoiceProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.FilterProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
reset() - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
reset() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
reset() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
reset() - Method in class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
reset() - Method in class org.apache.camel.processor.SendProcessor
 
resetAllCounters() - Static method in class org.apache.camel.impl.DefaultNodeIdFactory
Helper method for test purposes that allows tests to start clean (made protected to ensure that it is not called accidentally)
resetCacheStatistics() - Method in class org.apache.camel.impl.DefaultConsumerCache
Resets the cache statistics
resetCacheStatistics() - Method in class org.apache.camel.impl.DefaultProducerCache
Resets the cache statistics
resetCounters() - Method in class org.apache.camel.impl.ReloadStrategySupport
 
resetDebugCounter() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resetDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Resets the duplicate message counter to 0L.
resetMocks(CamelContext) - Static method in class org.apache.camel.component.mock.MockEndpoint
Reset all mock endpoints
resetStatistics() - Method in class org.apache.camel.impl.ServicePool
 
resetTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
resolve(CamelContext, String) - Static method in class org.apache.camel.component.mock.MockEndpoint
A helper method to resolve the mock endpoint of the given URI on the given context
resolve(CamelContext) - Method in class org.apache.camel.impl.HeadersMapFactoryResolver
 
resolve(CamelContext, String) - Method in class org.apache.camel.processor.SendDynamicAwareResolver
 
resolveClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveComponent(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveComponent(String, CamelContext) - Method in class org.apache.camel.impl.DefaultComponentResolver
 
resolveComponentDefaultName(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveDataFormat(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.DefaultDataFormatResolver
 
resolveDataFormatDefinition(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveDataFormatDefinition(String) - Method in interface org.apache.camel.model.ModelCamelContext
Resolve a data format definition given its name
resolveDefaultFactoryFinder(ClassResolver) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
 
resolveEndpoint(String) - Method in class org.apache.camel.impl.DefaultRouteContext
 
resolveEndpoint(String, String) - Method in class org.apache.camel.impl.DefaultRouteContext
 
resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.FromDefinition
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.Enricher
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.PollEnricher
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
 
resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
resolveEndpoint(RoutingSlip.RoutingSlipIterator, Exchange) - Method in class org.apache.camel.processor.RoutingSlip
 
resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveEndpoint(CamelContext, String) - Method in class org.apache.camel.reifier.RouteReifier
 
resolveExchangePattern(Object) - Method in class org.apache.camel.processor.RecipientListProcessor
 
resolveFactoryFinder(ClassResolver, String) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
 
resolveKnownConstantFields(Object) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Inspects the given definition and resolves known fields

This implementation will check all the getter/setter pairs on this instance and for all the values (which is a String type) will check if it refers to a known field (such as on Exchange).

resolveLanguage(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
resolveManagementName(String, String, boolean) - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
Creates a new management name with the given pattern
resolveMandatoryClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
resolveOptionalExternalScript(CamelContext, String) - Static method in class org.apache.camel.builder.ScriptHelper
Resolves the expression/predicate whether it refers to an external script on the file/classpath etc.
resolveOptionalExternalScript(CamelContext, Exchange, String) - Static method in class org.apache.camel.builder.ScriptHelper
Resolves the expression/predicate whether it refers to an external script on the file/classpath etc.
resolvePolicy(RouteContext) - Method in class org.apache.camel.reifier.TransactedReifier
 
resolvePolicy(RouteContext, TransactedDefinition) - Static method in class org.apache.camel.reifier.TransactedReifier
 
resolvePolicy(RouteContext, String, Class<? extends Policy>) - Static method in class org.apache.camel.reifier.TransactedReifier
 
resolvePropertyPlaceholders(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolvePropertyPlaceholders(CamelContext, Object) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Inspects the given definition and resolves any property placeholders from its properties.
resolveScheme(Exchange, String) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveSpoolDirectory(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
resolveThreadName(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
resolveTransformer(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveTransformer(DataType, DataType) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveTransformer(TransformerKey) - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
resolveUri(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveValidator(DataType) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resolveValidator(ValidatorKey) - Method in class org.apache.camel.impl.DefaultValidatorRegistry
 
resolveVariable(QName) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultComponentResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultProcessorFactory
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.HeadersMapFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.model.cloud.ServiceCallDefinitionConstants
 
RESOURCE_PATH - Static variable in class org.apache.camel.processor.SendDynamicAwareResolver
 
responseMessage(RestOperationResponseMsgDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
 
responseMessage() - Method in class org.apache.camel.model.rest.RestDefinition
 
responseMessage(VerbDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
 
responseMessages(List<RestOperationResponseMsgDefinition>) - Method in class org.apache.camel.model.rest.RestDefinition
 
responseModel(Class<?>) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
The response model
rest() - Method in class org.apache.camel.builder.RouteBuilder
Creates a new REST service
rest(String) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new REST service
rest() - Method in class org.apache.camel.model.rest.RestsDefinition
Creates a rest DSL
rest(String) - Method in class org.apache.camel.model.rest.RestsDefinition
Creates a rest DSL
rest(RestDefinition) - Method in class org.apache.camel.model.rest.RestsDefinition
RestBindingAdvice - Class in org.apache.camel.processor
A CamelInternalProcessorAdvice that binds the REST DSL incoming and outgoing messages from sources of json or xml to Java Objects.
RestBindingAdvice(CamelContext, DataFormat, DataFormat, DataFormat, DataFormat, String, String, String, boolean, boolean, boolean, Map<String, String>, Map<String, String>, boolean, Set<String>, Set<String>) - Constructor for class org.apache.camel.processor.RestBindingAdvice
 
RestBindingDefinition - Class in org.apache.camel.model.rest
To configure rest binding
RestBindingDefinition() - Constructor for class org.apache.camel.model.rest.RestBindingDefinition
 
RestBindingMode - Enum in org.apache.camel.model.rest
 
RestBindingReifier - Class in org.apache.camel.reifier.rest
 
RestBindingReifier(RestBindingDefinition) - Constructor for class org.apache.camel.reifier.rest.RestBindingReifier
 
restConfiguration() - Method in class org.apache.camel.builder.RouteBuilder
Configures the REST services
restConfiguration(String) - Method in class org.apache.camel.builder.RouteBuilder
Configures the REST service for the given component
RestConfigurationDefinition - Class in org.apache.camel.model.rest
To configure rest
RestConfigurationDefinition() - Constructor for class org.apache.camel.model.rest.RestConfigurationDefinition
 
RestConstants - Class in org.apache.camel.model.rest
 
RestContainer - Interface in org.apache.camel.model.rest
Container to hold Rest.
RestContextRefDefinition - Class in org.apache.camel.model
To refer to an XML file with rest services defined using the rest-dsl
RestContextRefDefinition() - Constructor for class org.apache.camel.model.RestContextRefDefinition
 
RestContextRefDefinitionHelper - Class in org.apache.camel.model
RestDefinition - Class in org.apache.camel.model.rest
Defines a rest service using the rest-dsl
RestDefinition() - Constructor for class org.apache.camel.model.rest.RestDefinition
 
RestHostNameResolver - Enum in org.apache.camel.model.rest
To configure the rest hostname resolver
RestOperationParamDefinition - Class in org.apache.camel.model.rest
To specify the rest operation parameters using Swagger.
RestOperationParamDefinition() - Constructor for class org.apache.camel.model.rest.RestOperationParamDefinition
 
RestOperationParamDefinition(VerbDefinition) - Constructor for class org.apache.camel.model.rest.RestOperationParamDefinition
 
RestOperationResponseHeaderDefinition - Class in org.apache.camel.model.rest
To specify the rest operation response headers using Swagger.
RestOperationResponseHeaderDefinition(RestOperationResponseMsgDefinition) - Constructor for class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
RestOperationResponseHeaderDefinition() - Constructor for class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
RestOperationResponseMsgDefinition - Class in org.apache.camel.model.rest
To specify the rest operation response messages using Swagger.
RestOperationResponseMsgDefinition(VerbDefinition) - Constructor for class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
RestOperationResponseMsgDefinition() - Constructor for class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
restoreTimeoutMapFromAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Restores the timeout map with timeout values from the aggregation repository.
RestParamType - Enum in org.apache.camel.model.rest
Rest parameter types
RestPropertyDefinition - Class in org.apache.camel.model.rest
A key value pair
RestPropertyDefinition() - Constructor for class org.apache.camel.model.rest.RestPropertyDefinition
 
RestPropertyDefinition(String, String) - Constructor for class org.apache.camel.model.rest.RestPropertyDefinition
 
RestsDefinition - Class in org.apache.camel.model.rest
A series of rest services defined using the rest-dsl
RestsDefinition() - Constructor for class org.apache.camel.model.rest.RestsDefinition
 
RestSecuritiesDefinition - Class in org.apache.camel.model.rest
To configure rest security definitions.
RestSecuritiesDefinition() - Constructor for class org.apache.camel.model.rest.RestSecuritiesDefinition
 
RestSecuritiesDefinition(RestDefinition) - Constructor for class org.apache.camel.model.rest.RestSecuritiesDefinition
 
RestSecurityApiKey - Class in org.apache.camel.model.rest
Rest security basic auth definition
RestSecurityApiKey() - Constructor for class org.apache.camel.model.rest.RestSecurityApiKey
 
RestSecurityApiKey(RestDefinition) - Constructor for class org.apache.camel.model.rest.RestSecurityApiKey
 
RestSecurityBasicAuth - Class in org.apache.camel.model.rest
Rest security basic auth definition
RestSecurityBasicAuth() - Constructor for class org.apache.camel.model.rest.RestSecurityBasicAuth
 
RestSecurityBasicAuth(RestDefinition) - Constructor for class org.apache.camel.model.rest.RestSecurityBasicAuth
 
RestSecurityDefinition - Class in org.apache.camel.model.rest
To specify the rest security definitions using Swagger.
RestSecurityDefinition() - Constructor for class org.apache.camel.model.rest.RestSecurityDefinition
 
RestSecurityDefinition(RestDefinition) - Constructor for class org.apache.camel.model.rest.RestSecurityDefinition
 
RestSecurityOAuth2 - Class in org.apache.camel.model.rest
Rest security OAuth2 definition
RestSecurityOAuth2() - Constructor for class org.apache.camel.model.rest.RestSecurityOAuth2
 
RestSecurityOAuth2(RestDefinition) - Constructor for class org.apache.camel.model.rest.RestSecurityOAuth2
 
resultType(Class<?>) - Method in class org.apache.camel.builder.SimpleBuilder
 
resultType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to the given resultType
resume() - Method in class org.apache.camel.impl.AbstractCamelContext
 
resumeAll() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resumeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resumeRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
resumeRoute(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
resumeRoute(String) - Method in class org.apache.camel.impl.DefaultRouteController
 
resumeRoute(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
resumeRouteService(RouteService) - Method in class org.apache.camel.impl.AbstractCamelContext
Resumes the given route service
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the logging level to use when retries has exhausted
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the logging level to use when retries has exhausted
retriesExhaustedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
retryAttemptedLogInterval(int) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retryAttemptedLogInterval(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the interval to use for logging retry attempts
retryAttemptedLogInterval - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
retryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the interval to log retry attempts
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the logging level to use for logging retry attempts
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the logging level to use for logging retry attempts
retryAttemptedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
retryDelay(long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
Sets the delay in millis between retries
retryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
retryWhile - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retryWhile(Expression) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the retry while expression.
retryWhile(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the retry while predicate.
retryWhilePolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
retryWhileRef - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
returnReplyBody(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the expression which value will be set to the message body
returnReplyHeader(String, Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the expression which value will be set to the message header
reverse() - Method in class org.apache.camel.model.ResequenceDefinition
Enables reverse mode for the batch resequencer mode.
ribbonLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
ribbonLoadBalancer(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
ribbonLoadBalancer() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
ribbonLoadBalancer(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
RibbonServiceCallServiceLoadBalancerConfiguration - Class in org.apache.camel.model.cloud
 
RibbonServiceCallServiceLoadBalancerConfiguration() - Constructor for class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
RibbonServiceCallServiceLoadBalancerConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
 
rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
rollback() - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback only and sets an exception with a default message.
rollback(String) - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback and sets an exception with the provided message.
RollbackDefinition - Class in org.apache.camel.model
Forces a rollback by stopping routing the message
RollbackDefinition() - Constructor for class org.apache.camel.model.RollbackDefinition
 
RollbackDefinition(String) - Constructor for class org.apache.camel.model.RollbackDefinition
 
RollbackProcessor - Class in org.apache.camel.processor
Processor for marking an Exchange to rollback.
RollbackProcessor() - Constructor for class org.apache.camel.processor.RollbackProcessor
 
RollbackProcessor(String) - Constructor for class org.apache.camel.processor.RollbackProcessor
 
roundRobin() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses round robin load balancer
RoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the round robin load balancing policy
RoundRobinLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
RoundRobinLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Round robin load balancer The round robin load balancer will use the next endpoint for each message.
RoundRobinLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
 
RoundRobinServiceChooser - Class in org.apache.camel.impl.cloud
 
RoundRobinServiceChooser() - Constructor for class org.apache.camel.impl.cloud.RoundRobinServiceChooser
 
route() - Method in class org.apache.camel.model.rest.RestDefinition
 
route() - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route
route(RouteDefinition) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route using the given route
RouteBuilder - Class in org.apache.camel.builder
A Java DSL which is used to build DefaultRoute instances in a CamelContext for smart routing.
RouteBuilder() - Constructor for class org.apache.camel.builder.RouteBuilder
 
RouteBuilder(CamelContext) - Constructor for class org.apache.camel.builder.RouteBuilder
 
routeBuilderClasses - Variable in class org.apache.camel.main.MainSupport
 
RouteBuilderDefinition - Class in org.apache.camel.model
To refer to a Java RouteBuilder instance to use.
RouteBuilderDefinition() - Constructor for class org.apache.camel.model.RouteBuilderDefinition
 
RouteBuilderDefinition(String) - Constructor for class org.apache.camel.model.RouteBuilderDefinition
 
routeBuilders - Variable in class org.apache.camel.main.MainSupport
 
RouteContainer - Interface in org.apache.camel.model
Container to hold Route.
RouteContextRefDefinition - Class in org.apache.camel.model
To refer to an XML file with routes defined using the xml-dsl
RouteContextRefDefinition() - Constructor for class org.apache.camel.model.RouteContextRefDefinition
 
RouteContextRefDefinitionHelper - Class in org.apache.camel.model
RouteDefinition - Class in org.apache.camel.model
A Camel route
RouteDefinition() - Constructor for class org.apache.camel.model.RouteDefinition
 
RouteDefinition(String) - Constructor for class org.apache.camel.model.RouteDefinition
 
RouteDefinition(Endpoint) - Constructor for class org.apache.camel.model.RouteDefinition
 
RouteDefinitionHelper - Class in org.apache.camel.model
Helper for RouteDefinition

Utility methods to help preparing RouteDefinition before they are added to CamelContext.

routeDescription(String) - Method in class org.apache.camel.model.ProcessorDefinition
Set the route description for this route
routeDescription(String) - Method in class org.apache.camel.model.RouteDefinition
Set the route description for this route
routeGroup(String) - Method in class org.apache.camel.model.ProcessorDefinition
Set the route group for this route.
routeGroup(String) - Method in class org.apache.camel.model.RouteDefinition
Set the route group for this route
routeId(String) - Method in class org.apache.camel.model.ProcessorDefinition
Set the route id for this route.
routeId(String) - Method in class org.apache.camel.model.RouteDefinition
Set the route id for this route
routeIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an Expression for the route id
RouteIdFactory - Class in org.apache.camel.impl
Factory for generating route ids based on uris.
RouteIdFactory() - Constructor for class org.apache.camel.impl.RouteIdFactory
 
RouteIdFactory(NodeIdFactory) - Constructor for class org.apache.camel.impl.RouteIdFactory
 
RouteInflightRepositoryAdvice(InflightRepository, String) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
RouteLifecycleAdvice() - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
routePolicy(RoutePolicy...) - Method in class org.apache.camel.model.RouteDefinition
Configures route policies for this route
RoutePolicyAdvice(List<RoutePolicy>) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
routePolicyRef(String) - Method in class org.apache.camel.model.RouteDefinition
Configures a route policy for this route
routeProperty(String, String) - Method in class org.apache.camel.model.RouteDefinition
Adds a custom property on the route.
RouteReifier - Class in org.apache.camel.reifier
 
RouteReifier(ProcessorDefinition<?>) - Constructor for class org.apache.camel.reifier.RouteReifier
 
RoutesDefinition - Class in org.apache.camel.model
A series of Camel routes
RoutesDefinition() - Constructor for class org.apache.camel.model.RoutesDefinition
 
RouteService - Class in org.apache.camel.impl
Represents the runtime objects for a given RouteDefinition so that it can be stopped independently of other routes
RouteService(AbstractCamelContext, RouteDefinition, List<RouteContext>, List<Route>) - Constructor for class org.apache.camel.impl.RouteService
 
routeSupportsSuspension(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
routingSlip(Expression, String) - Method in class org.apache.camel.model.ProcessorDefinition
Routing Slip EIP: Creates a routing slip allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
routingSlip(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Routing Slip EIP: Creates a routing slip allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
routingSlip() - Method in class org.apache.camel.model.ProcessorDefinition
Routing Slip EIP: Creates a routing slip allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
RoutingSlip - Class in org.apache.camel.processor
Implements a Routing Slip pattern where the list of actual endpoints to send a message exchange to are dependent on the value of a message header.
RoutingSlip(CamelContext) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlip(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlip.RoutingSlipIterator - Interface in org.apache.camel.processor
The iterator to be used for retrieving the next routing slip(s) to be used.
RoutingSlipDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Routes a message through a series of steps that are pre-determined (the slip)
RoutingSlipDefinition() - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(String, String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(Expression, String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(Expression) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
rss() - Method in class org.apache.camel.builder.DataFormatClause
Uses the RSS data format
RssDataFormat - Class in org.apache.camel.model.dataformat
RSS data format is used for working with RSS sync feed Java Objects and transforming to XML and vice-versa.
RssDataFormat() - Constructor for class org.apache.camel.model.dataformat.RssDataFormat
 
run() - Method in class org.apache.camel.main.MainSupport
Runs this process with the given arguments, and will wait until completed, or the JVM terminates.
run(String[]) - Method in class org.apache.camel.main.MainSupport
Parses the command line arguments then runs the program.
run() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer.State
 
run() - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
run() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
run() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
Redelivery logic.
run() - Method in class org.apache.camel.processor.resequencer.Timeout
Notifies the timeout handler about the scheduled timeout.
RuntimeBeanExpressionException - Exception in org.apache.camel.language.bean
Exception thrown if invocation of bean failed.
RuntimeBeanExpressionException(Exchange, String, String, Throwable) - Constructor for exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
RuntimeBeanExpressionException(Exchange, String, String, String) - Constructor for exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
runtimeRatioSum - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 

S

safelyStartRouteServices(boolean, boolean, boolean, boolean, Collection<RouteService>) - Method in class org.apache.camel.impl.AbstractCamelContext
Starts the routes services in a proper manner which ensures the routes will be started in correct order, check for clash and that the routes will also be shutdown in correct order as well.
safelyStartRouteServices(boolean, boolean, boolean, boolean, boolean, RouteService...) - Method in class org.apache.camel.impl.AbstractCamelContext
 
saga() - Method in class org.apache.camel.model.ProcessorDefinition
Marks this route as participating to a saga.
SagaActionUriDefinition - Class in org.apache.camel.model
Allows to declare saga actions to complete or compensate a saga
SagaActionUriDefinition() - Constructor for class org.apache.camel.model.SagaActionUriDefinition
 
SagaActionUriDefinition(String) - Constructor for class org.apache.camel.model.SagaActionUriDefinition
 
SagaCompletionMode - Enum in org.apache.camel.model
Enumerates all saga completion modes.
SagaDefinition - Class in org.apache.camel.model
Enables sagas on the route
SagaDefinition() - Constructor for class org.apache.camel.model.SagaDefinition
 
SagaOptionDefinition - Class in org.apache.camel.model
Allows to declare options on sagas
SagaOptionDefinition() - Constructor for class org.apache.camel.model.SagaOptionDefinition
 
SagaOptionDefinition(String, Expression) - Constructor for class org.apache.camel.model.SagaOptionDefinition
 
SagaProcessor - Class in org.apache.camel.processor.saga
Processor for handling sagas.
SagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.SagaProcessor
 
SagaProcessorBuilder - Class in org.apache.camel.processor.saga
Builder of Saga processors.
SagaProcessorBuilder() - Constructor for class org.apache.camel.processor.saga.SagaProcessorBuilder
 
SagaPropagation - Enum in org.apache.camel.model
Enumerates all saga propagation modes.
sagaService(CamelSagaService) - Method in class org.apache.camel.model.SagaDefinition
 
sagaService - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
sagaService(CamelSagaService) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
sample() - Method in class org.apache.camel.model.ProcessorDefinition
Sampling Throttler Creates a sampling throttler allowing you to extract a sample of exchanges from the traffic on a route.
sample(long, TimeUnit) - Method in class org.apache.camel.model.ProcessorDefinition
Sampling Throttler Creates a sampling throttler allowing you to extract a sample of exchanges from the traffic through a route.
sample(long) - Method in class org.apache.camel.model.ProcessorDefinition
Sampling Throttler Creates a sampling throttler allowing you to extract a sample of exchanges from the traffic through a route.
sampleMessageFrequency(long) - Method in class org.apache.camel.model.SamplingDefinition
Sets the sample message count which only a single Exchange will pass through after this many received.
samplePeriod(long) - Method in class org.apache.camel.model.SamplingDefinition
Sets the sample period during which only a single Exchange will pass through.
SamplingDefinition - Class in org.apache.camel.model
Extract a sample of the messages passing through a route
SamplingDefinition() - Constructor for class org.apache.camel.model.SamplingDefinition
 
SamplingDefinition(long, TimeUnit) - Constructor for class org.apache.camel.model.SamplingDefinition
 
SamplingDefinition(long) - Constructor for class org.apache.camel.model.SamplingDefinition
 
SamplingThrottler - Class in org.apache.camel.processor
A SamplingThrottler is a special kind of throttler.
SamplingThrottler(long) - Constructor for class org.apache.camel.processor.SamplingThrottler
 
SamplingThrottler(long, TimeUnit) - Constructor for class org.apache.camel.processor.SamplingThrottler
 
sanitizeHostName(String) - Static method in class org.apache.camel.impl.DefaultUuidGenerator
 
sanityCheckRoute(RouteDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Sanity check the route, that it has input(s) and outputs.
saxon() - Method in class org.apache.camel.builder.xml.XPathBuilder
Configures to use Saxon as the XPathFactory which allows you to use XPath 2.0 functions which may not be part of the build in JDK XPath parser.
schedule(Runnable) - Method in class org.apache.camel.processor.MulticastProcessor
 
schedule(Executor, Runnable, long, TimeUnit) - Method in class org.apache.camel.processor.MulticastProcessor
 
schedule() - Method in class org.apache.camel.processor.resequencer.Timeout
Schedules this timeout task.
scheme(String) - Method in class org.apache.camel.builder.TransformerBuilder
Set the scheme name supported by the transformer.
scheme(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific scheme such as http/https
script(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Executes a script (do not change the message body).
script() - Method in class org.apache.camel.model.ProcessorDefinition
Executes a script (do not change the message body).
ScriptDefinition - Class in org.apache.camel.model
Executes a script from a language which does not change the message body.
ScriptDefinition() - Constructor for class org.apache.camel.model.ScriptDefinition
 
ScriptDefinition(Expression) - Constructor for class org.apache.camel.model.ScriptDefinition
 
ScriptHelper - Class in org.apache.camel.builder
 
ScriptProcessor - Class in org.apache.camel.processor
A processor which executes the script as an expression and does not change the message body.
ScriptProcessor(Expression) - Constructor for class org.apache.camel.processor.ScriptProcessor
 
seconds() - Method in class org.apache.camel.component.mock.TimeClause.TimeClassUnit
 
secureXML() - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, byte[]) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, byte[]) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, byte[], String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, byte[], String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String, String, KeyStoreParameters) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String, String, KeyStoreParameters, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
security(String) - Method in class org.apache.camel.model.rest.RestDefinition
Sets the security setting for this verb.
security(String, String) - Method in class org.apache.camel.model.rest.RestDefinition
Sets the security setting for this verb.
SecurityDefinition - Class in org.apache.camel.model.rest
Rest security definition
SecurityDefinition() - Constructor for class org.apache.camel.model.rest.SecurityDefinition
 
securityDefinitions() - Method in class org.apache.camel.model.rest.RestDefinition
To configure security definitions.
select(Collection<ServiceRegistry>) - Method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByAttribute
 
select(Collection<ServiceRegistry>) - Method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByOrder
 
select(Collection<ServiceRegistry>) - Method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByType
 
select(Collection<ServiceRegistry>) - Method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectFirst
 
select(Collection<ServiceRegistry>) - Method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectSingle
 
SelectByAttribute(String, Object) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByAttribute
 
SelectByOrder() - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByOrder
 
SelectByType(Class<? extends ServiceRegistry>) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectByType
 
selectFirst() - Method in class org.apache.camel.builder.AdviceWithBuilder
Will only apply the first node matched.
SelectFirst() - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectFirst
 
selectIndex(int) - Method in class org.apache.camel.builder.AdviceWithBuilder
Will only apply the n'th node matched.
selectLast() - Method in class org.apache.camel.builder.AdviceWithBuilder
Will only apply the last node matched.
selectRange(int, int) - Method in class org.apache.camel.builder.AdviceWithBuilder
Will only apply the node in the index range matched.
SelectSingle() - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrySelectors.SelectSingle
 
send() - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
send(Endpoint, Exchange, Processor) - Method in class org.apache.camel.impl.DefaultProducerCache
Sends the exchange to the given endpoint.
send(String, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(String, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, ExchangePattern, Processor, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Exchange, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Endpoint, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(String, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
SendDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Sends the message to an endpoint
SendDefinition() - Constructor for class org.apache.camel.model.SendDefinition
 
SendDefinition(String) - Constructor for class org.apache.camel.model.SendDefinition
 
SendDynamicAwareResolver - Class in org.apache.camel.processor
 
SendDynamicAwareResolver() - Constructor for class org.apache.camel.processor.SendDynamicAwareResolver
 
sendDynamicProcessor - Variable in class org.apache.camel.processor.RoutingSlip
 
SendDynamicProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to a dynamic endpoint destination.
SendDynamicProcessor(Expression) - Constructor for class org.apache.camel.processor.SendDynamicProcessor
 
SendDynamicProcessor(String, Expression) - Constructor for class org.apache.camel.processor.SendDynamicProcessor
 
sendElement(E) - Method in interface org.apache.camel.processor.resequencer.SequenceSender
Sends the given element.
sendElement(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
Sends the exchange to the next processor.
sendMessages(long, long) - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
SendProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to a static endpoint destination.
SendProcessor(Endpoint) - Constructor for class org.apache.camel.processor.SendProcessor
 
SendProcessor(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.processor.SendProcessor
 
sendToRecipientList(Exchange, Object, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
Sends the given exchange to the recipient list
Sequence<E> - Class in org.apache.camel.processor.resequencer
A sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.
Sequence(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.Sequence
Creates a new Sequence instance.
SequenceElementComparator<E> - Interface in org.apache.camel.processor.resequencer
A strategy for comparing elements of a sequence.
SequenceSender<E> - Interface in org.apache.camel.processor.resequencer
An interface used by the ResequencerEngine.deliver() and ResequencerEngine.deliverNext() methods to send out re-ordered elements.
serialization() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Java Serialization data format
SerializationDataFormat - Class in org.apache.camel.impl
The data format using Java Serialization.
SerializationDataFormat() - Constructor for class org.apache.camel.impl.SerializationDataFormat
 
SerializationDataFormat - Class in org.apache.camel.model.dataformat
Serialization is a data format which uses the standard Java Serialization mechanism to unmarshal a binary payload into Java objects or to marshal Java objects into a binary blob.
SerializationDataFormat() - Constructor for class org.apache.camel.model.dataformat.SerializationDataFormat
 
servers(List<String>) - Method in class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
Sets the server blacklist.
servers(String) - Method in class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
Sets the server blacklist.
servers(List<String>) - Method in class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
Sets the server list.
servers(String) - Method in class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
Sets the server list.
serviceCall() - Method in class org.apache.camel.model.ProcessorDefinition
Calls the service
serviceCall(String) - Method in class org.apache.camel.model.ProcessorDefinition
Calls the service
serviceCall(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Calls the service
serviceCallConfiguration(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Refers to a ServiceCall configuration to use
ServiceCallConfigurationDefinition - Class in org.apache.camel.model.cloud
Remote service call configuration
ServiceCallConfigurationDefinition() - Constructor for class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
ServiceCallDefinition - Class in org.apache.camel.model.cloud
To call remote services
ServiceCallDefinition() - Constructor for class org.apache.camel.model.cloud.ServiceCallDefinition
 
ServiceCallDefinitionConstants - Class in org.apache.camel.model.cloud
 
ServiceCallExpressionConfiguration - Class in org.apache.camel.model.cloud
 
ServiceCallExpressionConfiguration() - Constructor for class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
ServiceCallExpressionConfiguration(ServiceCallDefinition, String) - Constructor for class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
ServiceCallServiceChooserConfiguration - Class in org.apache.camel.model.cloud
 
ServiceCallServiceChooserConfiguration() - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
ServiceCallServiceChooserConfiguration(ServiceCallDefinition, String) - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
 
ServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
ServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
ServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition, String) - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
 
ServiceCallServiceFilterConfiguration - Class in org.apache.camel.model.cloud
 
ServiceCallServiceFilterConfiguration() - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
ServiceCallServiceFilterConfiguration(ServiceCallDefinition, String) - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
 
ServiceCallServiceLoadBalancerConfiguration - Class in org.apache.camel.model.cloud
 
ServiceCallServiceLoadBalancerConfiguration() - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
ServiceCallServiceLoadBalancerConfiguration(ServiceCallDefinition, String) - Constructor for class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
 
serviceChooser(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceChooser to use.
serviceChooser(ServiceChooser) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceChooser to use.
serviceChooser(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceChooser to use.
serviceChooser(ServiceChooser) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceChooser to use.
serviceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceDiscovery to use.
serviceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceDiscovery to use.
serviceDiscovery(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceDiscovery to use.
serviceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceDiscovery to use.
serviceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the service-call configuration to use
serviceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
Add a ServiceDiscovery configuration
serviceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the ServiceDiscovery using the given configuration.
serviceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the ServiceDiscovery using the given configuration.
serviceDiscoveryConfigurations(List<ServiceCallServiceDiscoveryConfiguration>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
List of ServiceDiscovery configuration to use
serviceFilter(String) - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
Reference of a ServiceFilter
serviceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
Set the ServiceFilter
serviceFilter(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceFilter to use.
serviceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceFilter to use.
serviceFilter(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceFilter to use.
serviceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceFilter to use.
serviceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
Add a ServiceFilter configuration
serviceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the ServiceFilter using the given configuration.
serviceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the ServiceFilter using the given configuration.
serviceFilterConfigurations(List<ServiceCallServiceFilterConfiguration>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
List of ServiceFilter configuration to use
servicePath(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The path to look for for service discovery
ServicePool<S extends org.apache.camel.Service> - Class in org.apache.camel.impl
A service pool is like a connection pool but can pool any kind of objects.
ServicePool(ThrowingFunction<Endpoint, S, Exception>, Function<S, Endpoint>, int) - Constructor for class org.apache.camel.impl.ServicePool
 
ServiceRegistrationRoutePolicy - Class in org.apache.camel.impl.cloud
 
ServiceRegistrationRoutePolicy() - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
ServiceRegistrationRoutePolicy(ServiceRegistry.Selector) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
ServiceRegistrationRoutePolicy(ServiceRegistry, ServiceRegistry.Selector) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
ServiceRegistrationRoutePolicyFactory - Class in org.apache.camel.impl.cloud
 
ServiceRegistrationRoutePolicyFactory() - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicyFactory
 
ServiceRegistrationRoutePolicyFactory(ServiceRegistry.Selector) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicyFactory
 
ServiceRegistrationRoutePolicyFactory(ServiceRegistry, ServiceRegistry.Selector) - Constructor for class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicyFactory
 
ServiceRegistryHelper - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors.SelectByAttribute - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors.SelectByOrder - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors.SelectByType - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors.SelectFirst - Class in org.apache.camel.impl.cloud
 
ServiceRegistrySelectors.SelectSingle - Class in org.apache.camel.impl.cloud
 
sessionTimeout(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
set(CamelContext, String, RouteError.Phase, Throwable) - Static method in class org.apache.camel.impl.DefaultRouteError
 
setAcceptableSchemes(String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
setAclToken(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the ACL token to be used with Consul
setAction(DurationRoutePolicy.Action) - Method in class org.apache.camel.impl.DurationRoutePolicy
What action to perform when maximum is triggered.
setAction(DurationRoutePolicy.Action) - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
What action to perform when maximum is triggered.
setAddKeyValueForEncryptedKey(Boolean) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
Whether to add the public key used to encrypt the session key as a KeyValue in the EncryptedKey structure or not.
setAggregateController(AggregateController) - Method in class org.apache.camel.model.AggregateDefinition
 
setAggregateController(AggregateController) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregateControllerRef(String) - Method in class org.apache.camel.model.AggregateDefinition
To use a AggregateController to allow external sources to control this aggregator.
setAggregateOnException(Boolean) - Method in class org.apache.camel.model.EnrichDefinition
 
setAggregateOnException(Boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setAggregateOnException(boolean) - Method in class org.apache.camel.processor.Enricher
 
setAggregateOnException(boolean) - Method in class org.apache.camel.processor.PollEnricher
 
setAggregationRepository(AggregationRepository) - Method in class org.apache.camel.model.AggregateDefinition
 
setAggregationRepository(AggregationRepository) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregationRepositoryRef(String) - Method in class org.apache.camel.model.AggregateDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
The AggregationStrategy to use.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.EnrichDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.RecipientListDefinition
Sets the AggregationStrategy to be used to assemble the replies from the recipients, into a single outgoing message from the RecipientList.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitDefinition
Sets the AggregationStrategy to be used to assemble the replies from the splitted messages, into a single outgoing message from the Splitter.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.Enricher
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.PollEnricher
Sets the aggregation strategy for this poll enricher.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.RecipientList
 
setAggregationStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.EnrichDefinition
 
setAggregationStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.AggregateDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.EnrichDefinition
 
setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setAggregationStrategyOnExchange(Exchange, AggregationStrategy) - Method in class org.apache.camel.processor.MulticastProcessor
Sets the given AggregationStrategy on the Exchange.
setAggregationStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
A reference to lookup the AggregationStrategy in the Registry.
setAggregationStrategyRef(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setAggregationStrategyRef(String) - Method in class org.apache.camel.model.EnrichDefinition
 
setAggregationStrategyRef(String) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setAlgorithm(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
The JCE algorithm name indicating the cryptographic algorithm that will be used.
setAlgorithm(Integer) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Symmetric key encryption algorithm; possible values are defined in org.bouncycastle.bcpg.SymmetricKeyAlgorithmTags; for example 2 (= TRIPLE DES), 3 (= CAST5), 4 (= BLOWFISH), 6 (= DES), 7 (= AES_128).
setAlgorithmParameterRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
A JCE AlgorithmParameterSpec used to initialize the Cipher.
setAliases(Map<String, String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Alias a Class to a shorter name to be used in XML elements.
setAllowableValues(List<String>) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter list of allowable values (enum).
setAllowableValues(List<String>) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger Parameter list of allowable values.
setAllowAnyType(boolean) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Allow any class to be un-marshaled
setAllowCoreThreadTimeOut(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Whether idle core threads is allowed to timeout and therefore can shrink the pool size below the core pool size

Is by default false

setAllowCoreThreadTimeOut(Boolean) - Method in class org.apache.camel.model.ThreadsDefinition
 
setAllowDuplicates(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
Whether to allow duplicates.
setAllowDuplicates(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setAllowEasyPredicate(Boolean) - Method in class org.apache.camel.model.language.JsonPathExpression
Whether to allow using the easy predicate parser to pre-parse predicates.
setAllowEmptyDirectory(Boolean) - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
If the tar file has more then one entry, setting this option to true, allows to get the iterator even if the directory is empty
setAllowEmptyDirectory(Boolean) - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
If the zip file has more then one entry, setting this option to true, allows to get the iterator even if the directory is empty
setAllowJmsType(Boolean) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Used for JMS users to allow the JMSType header from the JMS spec to specify a FQN classname to use to unmarshal to.
setAllowJmsType(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Used for JMS users to allow the JMSType header from the JMS spec to specify a FQN classname to use to unmarshal to.
setAllowMaximumSizeToDivergeFromCoreSize(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Allows the configuration for maximumSize to take effect.
setAllowMissingColumnNames(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether to allow missing column names.
setAllowNullNewExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowNullOldExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowOptimisedComponents(Boolean) - Method in class org.apache.camel.model.ToDynamicDefinition
 
setAllowOptimisedComponents(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setAllowRedeliveryWhileStopping(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setAllowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
setAllowShortLines(Boolean) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
Allows for lines to be shorter than expected and ignores the extra characters
setAllowSimple(Boolean) - Method in class org.apache.camel.model.language.JsonPathExpression
Whether to allow in inlined simple exceptions in the JsonPath expression
setAllowUnmarshallType(Boolean) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
If enabled then Jackson is allowed to attempt to use the CamelJacksonUnmarshalType header during the unmarshalling.
setAllowUnmarshallType(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
If enabled then Jackson is allowed to attempt to use the CamelJacksonUnmarshalType header during the unmarshalling.
setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setAnyOrder(boolean) - Method in class org.apache.camel.component.test.TestEndpoint
Whether the expected messages should arrive in the same order or can be in any order.
setAnySpoolRules(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setApiComponent(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
The name of the Camel component to use as the REST API (such as swagger)
setApiContextIdPattern(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets an CamelContext id pattern to only allow Rest APIs from rest services within CamelContext's which name matches the pattern.
setApiContextListing(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets whether listing of all available CamelContext's with REST services in the JVM is enabled.
setApiContextPath(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets a leading API context-path the REST API services will be using.
setApiContextRouteId(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the route id to use for the route that services the REST API.
setApiDocs(Boolean) - Method in class org.apache.camel.model.rest.RestDefinition
Whether to include or exclude the VerbDefinition in API documentation.
setApiDocs(Boolean) - Method in class org.apache.camel.model.rest.VerbDefinition
Whether to include or exclude the VerbDefinition in API documentation.
setApiHost(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use an specific hostname for the API documentation (eg swagger)

This can be used to override the generated host with this configured hostname

setApiProperties(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure as many additional properties for the api documentation (swagger).
setApiVendorExtension(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether vendor extension is enabled in the Rest APIs.
setApiVersion(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the API version when using client lookup
setApplicationContextClassLoader(ClassLoader) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setArgs(Object[]) - Method in class org.apache.camel.component.bean.BeanInvocation
 
setArmored(Boolean) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
This option will cause PGP to base64 encode the encrypted text, making it available for copy/paste, etc.
setArrayType(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter array type.
setArrayType(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger Parameter array type.
setAsMap(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether the unmarshalling should produce maps for the lines values instead of lists.
setAssertPeriod(CamelContext, long) - Static method in class org.apache.camel.component.mock.MockEndpoint
Sets the assert period on all the expectations on any MockEndpoint instances registered in the given context.
setAssertPeriod(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets a grace period after which the mock endpoint will re-assert to ensure the preliminary assertion is still valid.
setAsyncDelayed(Boolean) - Method in class org.apache.camel.model.DelayDefinition
 
setAsyncDelayed(Boolean) - Method in class org.apache.camel.model.ThrottleDefinition
 
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.Throttler
 
setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setAsyncDelayedRedelivery(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether asynchronous delayed redelivery is allowed.
setAsyncProcessorAwaitManager(AsyncProcessorAwaitManager) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setAttribute(String, Object) - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
setAttributes(Map<String, Object>) - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
setAuthorizationUrl(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
The authorization URL to be used for this flow.
setAutoConfigurationEnabled(boolean) - Method in class org.apache.camel.main.MainSupport
Whether auto configuration of components/dataformats/languages is enabled or not.
setAutoCreateComponents(boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setAutoStartup(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setAutoStartup(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setAutoStartup(String) - Method in class org.apache.camel.model.RouteDefinition
Whether to auto start this route
setBacklogSize(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBackOff(String, BackOff) - Method in class org.apache.camel.impl.SupervisingRouteController
Sets the back-off to be applied to the given id.
setBackOffConfigurations(Map<String, BackOff>) - Method in class org.apache.camel.impl.SupervisingRouteController
Set the back-off for the given IDs.
setBackOffMultiplier(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setBackOffMultiplier(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the multiplier used to increase the delay between redeliveries if RedeliveryPolicy.setUseExponentialBackOff(boolean) is enabled
setBarcodeFormat(String) - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
Barcode format such as QR-Code
setBasePath(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Set the base path to store in ZK
setBatchConfig(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
 
setBatchConsumer(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setBatchSize(int) - Method in class org.apache.camel.model.config.BatchResequencerConfig
Sets the size of the batch to be re-ordered.
setBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the in batch size.
setBatchTimeout(long) - Method in class org.apache.camel.model.config.BatchResequencerConfig
Sets the timeout for collecting elements to be re-ordered.
setBatchTimeout(long) - Method in class org.apache.camel.processor.Resequencer
 
setBean(Object) - Method in class org.apache.camel.model.BeanDefinition
Sets an instance of the bean to use
setBeanHolder(BeanHolder) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
setBeanName(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
Sets the name of the bean to invoke
setBeanPostProcessor(CamelBeanPostProcessor) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setBeanReaderErrorHandlerType(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
To use a custom org.apache.camel.dataformat.beanio.BeanIOErrorHandler as error handler while parsing.
setBeanType(String) - Method in class org.apache.camel.model.BeanDefinition
Sets the Class of the bean
setBeanType(Class<?>) - Method in class org.apache.camel.model.BeanDefinition
Sets the Class of the bean
setBeanType(Class<?>) - Method in class org.apache.camel.model.language.MethodCallExpression
 
setBeanTypeName(String) - Method in class org.apache.camel.model.language.MethodCallExpression
Class name of the bean to use
setBinaryContent(Boolean) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
Defines whether the content of binary parts in the MIME multipart is binary (true) or Base-64 encoded (false)
setBindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Sets the binding mode to use.
setBindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the binding mode to use.
setBindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.RestDefinition
Sets the binding mode to use.
setBindingMode(RestBindingMode) - Method in class org.apache.camel.model.rest.VerbDefinition
Sets the binding mode to use.
setBindingName(String) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
To use a custom binding factory
setBlockSeconds(Integer) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The seconds to wait for a watch event, default 10 seconds
setBody() - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
setBody(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
setBody(Supplier<Result>) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
setBody(Function<Exchange, Result>) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
SetBodyDefinition - Class in org.apache.camel.model
Sets the contents of the message body
SetBodyDefinition() - Constructor for class org.apache.camel.model.SetBodyDefinition
 
SetBodyDefinition(Expression) - Constructor for class org.apache.camel.model.SetBodyDefinition
 
setBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
SetBodyProcessor - Class in org.apache.camel.processor
A processor which sets the body on the IN or OUT message with an Expression
SetBodyProcessor(Expression) - Constructor for class org.apache.camel.processor.SetBodyProcessor
 
setBufferSize(int) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setBuffersize(Integer) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
The size of the buffer used in the signature process.
setCaCertData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Certificate Authority data when using client lookup
setCaCertFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Certificate Authority data that are loaded from the file when using client lookup
setCache(Boolean) - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
setCache(Boolean) - Method in class org.apache.camel.component.bean.BeanComponent
If enabled, Camel will cache the result of the first Registry look-up.
setCache(Boolean) - Method in class org.apache.camel.component.bean.BeanEndpoint
If enabled, Camel will cache the result of the first Registry look-up.
setCache(Boolean) - Method in class org.apache.camel.component.bean.BeanProcessor
 
setCache(Map<String, String>) - Method in class org.apache.camel.impl.FileStateRepository
 
setCache(Boolean) - Method in class org.apache.camel.model.BeanDefinition
Caches the bean lookup, to avoid lookup up bean on every usage.
setCacheSize(Integer) - Method in class org.apache.camel.model.DynamicRouterDefinition
 
setCacheSize(Integer) - Method in class org.apache.camel.model.EnrichDefinition
 
setCacheSize(Integer) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setCacheSize(Integer) - Method in class org.apache.camel.model.RecipientListDefinition
 
setCacheSize(Integer) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
setCacheSize(Integer) - Method in class org.apache.camel.model.ToDynamicDefinition
 
setCacheSize(int) - Method in class org.apache.camel.processor.Enricher
 
setCacheSize(int) - Method in class org.apache.camel.processor.PollEnricher
 
setCacheSize(int) - Method in class org.apache.camel.processor.RecipientList
 
setCacheSize(int) - Method in class org.apache.camel.processor.RoutingSlip
 
setCacheSize(int) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.DelayDefinition
 
setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.ThreadsDefinition
 
setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.ThrottleDefinition
 
setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.Throttler
 
setCamelContext(CamelContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cloud.DefaultServiceDiscovery
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cloud.ServiceRegistrationRoutePolicy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultClassResolver
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultDebugger
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultRestRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultRouteController
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DurationRoutePolicy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.ReloadStrategySupport
 
setCamelContext(ModelCamelContext) - Method in class org.apache.camel.model.rest.RestsDefinition
 
setCamelContext(ModelCamelContext) - Method in class org.apache.camel.model.RoutesDefinition
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.Enricher
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.PollEnricher
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.WireTapProcessor
 
setCapacity(int) - Method in class org.apache.camel.model.config.StreamResequencerConfig
Sets the capacity of the resequencer's inbound queue.
setCapacity(int) - Method in class org.apache.camel.processor.StreamResequencer
 
setCharset(String) - Method in class org.apache.camel.impl.StringDataFormat
 
setCharset(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
To use a specific charset when converting
setCharset(String) - Method in class org.apache.camel.model.dataformat.StringDataFormat
Sets an encoding to use.
setChildDefinition(ProcessorDefinition<?>) - Method in interface org.apache.camel.model.ModelChannel
If the initialized output definition contained outputs (children) then we need to set the child so we can leverage fine grained tracing
setChildDefinition(ProcessorDefinition<?>) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
setCircuitBreakerEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether to use a HystrixCircuitBreaker or not.
setCircuitBreakerErrorThresholdPercentage(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Error percentage threshold (as whole number such as 50) at which point the circuit breaker will trip open and reject requests.
setCircuitBreakerForceClosed(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
If true the HystrixCircuitBreaker#allowRequest() will always return true to allow requests regardless of the error percentage from HystrixCommandMetrics.getHealthCounts().
setCircuitBreakerForceOpen(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
If true the HystrixCircuitBreaker.allowRequest() will always return false, causing the circuit to be open (tripped) and reject all requests.
setCircuitBreakerRequestVolumeThreshold(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Minimum number of requests in the metricsRollingStatisticalWindowInMilliseconds() that must exist before the HystrixCircuitBreaker will trip.
setCircuitBreakerSleepWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
The time in milliseconds after a HystrixCircuitBreaker trips open that it should wait before trying requests again.
setClassLoader(ClassLoader) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Set a custom classloader
setClassName(String) - Method in class org.apache.camel.model.transformer.CustomTransformerDefinition
Set a class name of the Transformer
setClassName(String) - Method in class org.apache.camel.model.validator.CustomValidatorDefinition
Set a class name of the Validator
setClassResolver(ClassResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setClassType(String) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
Name of model class to use.
setClassType(Class<?>) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
Type of model class to use.
setClazzName(String) - Method in class org.apache.camel.model.dataformat.ASN1DataFormat
Name of class to use when unmarshalling
setClientCertData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Certificate data when using client lookup
setClientCertFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Certificate data that are loaded from the file when using client lookup
setClientKeyAlgo(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore algorithm, such as RSA when using client lookup
setClientKeyData(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore data when using client lookup
setClientKeyFile(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore data that are loaded from the file when using client lookup
setClientKeyPassphrase(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Client Keystore passphrase when using client lookup
setClientName(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
Sets the Ribbon client name
setClientRequestValidation(Boolean) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
setClientRequestValidation(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
setClientRequestValidation(Boolean) - Method in class org.apache.camel.model.rest.RestDefinition
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
setClientRequestValidation(Boolean) - Method in class org.apache.camel.model.rest.VerbDefinition
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.model.AggregateDefinition
 
setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterEntry
 
setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
setClusterService(CamelClusterService) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Set the cluster service to use.
setClusterServiceSelector(CamelClusterService.Selector) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Set the selector strategy to look-up a CamelClusterService
setCode(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
setCollectionFormat(CollectionFormat) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter collection format.
setCollectionFormat(CollectionFormat) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger Parameter collection format.
setCollectionTypeName(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Refers to a custom collection type to lookup in the registry to use.
setCollectionTypeName(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Refers to a custom collection type to lookup in the registry to use.
setCollisionAvoidanceFactor(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the factor used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the percentage used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setComment(String) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The comment symbol.
setCommentMarker(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the comment marker of the reference format.
setCommentMarkerDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Disables the comment marker of the reference format.
setComparator(ExpressionResultComparator) - Method in class org.apache.camel.model.config.StreamResequencerConfig
To use a custom comparator
setComparator(Comparator<T>) - Method in class org.apache.camel.model.SortDefinition
 
setComparatorRef(String) - Method in class org.apache.camel.model.config.StreamResequencerConfig
To use a custom comparator
setComparatorRef(String) - Method in class org.apache.camel.model.SortDefinition
 
setCompensation(SagaActionUriDefinition) - Method in class org.apache.camel.model.SagaDefinition
The compensation endpoint URI that must be called to compensate all changes done in the route.
setCompleteAllOnStop(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompleteAllOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletion(SagaActionUriDefinition) - Method in class org.apache.camel.model.SagaDefinition
The completion endpoint URI that will be called when the Saga is completed successfully.
setCompletionEager(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setCompletionFromBatchConsumer(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionFromBatchConsumer(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionInterval(Long) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionMode(SagaCompletionMode) - Method in class org.apache.camel.model.SagaDefinition
Determine how the saga should be considered complete.
setCompletionOnNewCorrelationGroup(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionOnNewCorrelationGroup(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.Resequencer
 
setCompletionSize(Integer) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionSize(int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionSizeExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionSizeExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeout(Long) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionTimeout(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutCheckerInterval(Long) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionTimeoutCheckerInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setCompletionTimeoutExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setComponent(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
The component to use.
setComponent(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
The component to use.
setComponent(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Sets the component name that this definition will apply to
setComponent(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
The Camel Rest component to use for the REST transport (consumer), such as restlet, spark-rest.
setComponentProperties(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure as many additional properties for the rest component in use.
setComponentResolver(ComponentResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setCompressionAlgorithm(Integer) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Compression algorithm; possible values are defined in org.bouncycastle.bcpg.CompressionAlgorithmTags; for example 0 (= UNCOMPRESSED), 1 (= ZIP), 2 (= ZLIB), 3 (= BZIP2).
setCompressionLevel(int) - Method in class org.apache.camel.impl.ZipDataFormat
 
setCompressionLevel(Integer) - Method in class org.apache.camel.model.dataformat.ZipDataFormat
To specify a specific compression between 0-9.
setConfigurationClasses(String) - Method in class org.apache.camel.main.MainSupport
 
setConfigurationRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Refers to a ServiceCall configuration to use
setConfigurations(List<Object>) - Method in class org.apache.camel.main.MainSupport
 
setConnectionTimeout(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Connection timeout.
setConnectTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Connect timeout for OkHttpClient
setConstructor(String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
BaseConstructor to construct incoming documents.
setConsumeDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Allows a delay to be specified which causes a delay when a message is consumed by the producer (to simulate slow processing)
setConsumerProperties(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure as many additional properties for the rest consumer in use.
setConsumes(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
To define the content type what the REST service consumes (accept as input), such as application/xml or application/json
setConsumes(String) - Method in class org.apache.camel.model.rest.RestDefinition
To define the content type what the REST service consumes (accept as input), such as application/xml or application/json.
setConsumes(String) - Method in class org.apache.camel.model.rest.VerbDefinition
To define the content type what the REST service consumes (accept as input), such as application/xml or application/json.
setContentTypeFormat(String) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
Defines a content type format in which protobuf message will be serialized/deserialized from(to) the Java been.
setContentTypeFormat(String) - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
Defines a content type format in which thrift message will be serialized/deserialized from(to) the Java been.
setContentTypeHeader(Boolean) - Method in class org.apache.camel.model.DataFormatDefinition
Whether the data format should set the Content-Type header with the type from the data format if the data format is capable of doing so.
setContext(CamelContext) - Method in class org.apache.camel.builder.BuilderSupport
 
setContext(ModelCamelContext) - Method in class org.apache.camel.builder.BuilderSupport
 
setContextCounter(int) - Static method in class org.apache.camel.impl.AbstractCamelContext
Reset context counter to a preset value.
setContextPath(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Package name where your JAXB classes are located.
setContextPath(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
Package name where your JAXB classes are located.
setContextPath(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets a leading context-path the REST services will be using.
setContinued(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setContinuedPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setConverters(List<String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
List of class names for using custom XStream converters.
setCopy(Boolean) - Method in class org.apache.camel.model.LoopDefinition
If the copy attribute is true, a copy of the input Exchange is used for each iteration.
setCopy(Boolean) - Method in class org.apache.camel.model.WireTapDefinition
 
setCopy(boolean) - Method in class org.apache.camel.processor.WireTapProcessor
 
setCopyOnExchange(boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets whether to make a deep copy of the incoming Exchange when received at this mock endpoint.
setCorePoolSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Core thread-pool size that gets passed to ThreadPoolExecutor.setCorePoolSize(int)
setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
The expression used to calculate the correlation key to use for aggregation.
setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
The correlation expression to use to calculate the correlation key
setCorrelationExpression(Expression) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.ThrottleDefinition
The expression used to calculate the correlation key to use for throttle grouping.
setCorrelationExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCorsHeaders(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure custom CORS headers.
setCounter(int) - Static method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
To reset the counter, should only be used for testing purposes.
setCounter(int) - Static method in class org.apache.camel.impl.DefaultManagementNameStrategy
To reset the counter, should only be used for testing purposes.
setCryptoProvider(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
The name of the JCE Security Provider that should be used.
setCurrentSagaCoordinator(Exchange, CamelSagaCoordinator) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
setCustomId(Boolean) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Whether the node id was explicit set, or was auto generated by Camel.
setCustomLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
The custom load balancer to use.
setDatacenter(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The data center
setDataFormat(DataFormat) - Method in class org.apache.camel.model.DataFormatDefinition
 
setDataFormat(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter data format.
setDataFormat(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger Parameter data format.
setDataFormatName(String) - Method in class org.apache.camel.model.DataFormatDefinition
 
setDataFormatProperties(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure as many additional properties for the data formats in use.
setDataFormatRef(String) - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
Set DataFormat ref.
setDataFormatResolver(DataFormatResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setDataFormats(Map<String, DataFormatDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setDataFormats(List<DataFormatDefinition>) - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
A list holding the configured data formats
setDataFormats(Map<String, DataFormatDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the data formats that can be referenced in the routes.
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
Set DataFormatDefinition.
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.MarshalDefinition
The data format to be used
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.transformer.DataFormatTransformerDefinition
The data format to be used
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.UnmarshalDefinition
The data format to be used
setDataObjectType(Class<?>) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
What data type to unmarshal as, can either be org.w3c.dom.Node or java.lang.String.
setDataObjectTypeName(String) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
What data type to unmarshal as, can either be org.w3c.dom.Node or java.lang.String.
setDataSet(DataSet) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
setDataSetIndex(String) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Controls the behaviour of the CamelDataSetIndex header.
setDataType(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter data type.
setDataType(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger header data type.
setDeadLetter(Endpoint) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setDeadLetterHandleNewException(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setDeadLetterUri(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setDebugger(Debugger) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
Sets the default aggregation strategy for this poll enricher.
setDefaultBackOff(BackOff) - Method in class org.apache.camel.impl.SupervisingRouteController
Sets the default back-off.
setDefaultBodies(List<Object>) - Method in class org.apache.camel.component.dataset.ListDataSet
 
setDefaultBody(Object) - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
Sets the default endpoint to use if none is specified
setDefaultExtension(Class<T>, Supplier<T>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setDefaultInstance(Object) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
 
setDefaultInstance(Object) - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
 
setDefaultProfile(Boolean) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Whether this profile is the default thread pool profile
setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
setDefaultValue(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
 
setDefinition(String) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
The flatpack pzmap configuration file.
setDelay(long) - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
Sets the delay in millis between checks for updated files.
setDelay(Expression) - Method in class org.apache.camel.processor.Delayer
 
setDelayer(Long) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setDelayer(Long) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setDelayer(String) - Method in class org.apache.camel.model.RouteDefinition
Whether to slow down processing messages by a given delay in msec.
setDelayPattern(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setDelayPattern(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets an optional delay pattern to use instead of fixed delay.
setDelimiter(String) - Method in class org.apache.camel.component.test.TestEndpoint
The split delimiter to use when split is enabled.
setDelimiter(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the delimiter to use.
setDelimiter(String) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
The delimiter char (could be ; , or similar)
setDelimiter(String) - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
The delimiter of values
setDelimiter(String) - Method in class org.apache.camel.model.RecipientListDefinition
 
setDelimiter(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setDeliveryAttemptInterval(Long) - Method in class org.apache.camel.model.config.StreamResequencerConfig
Sets the interval in milli seconds the stream resequencer will at most wait while waiting for condition of being able to deliver.
setDeliveryAttemptInterval(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setDescription(DescriptionDefinition) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the description of this node
setDescription(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter description.
setDescription(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
setDescription(String) - Method in class org.apache.camel.model.rest.RestSecurityDefinition
A short description for security scheme.
setDetour(Processor) - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
setDigestAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The digest algorithm to use with the RSA OAEP algorithm.
setDisableFeatures(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Set of features to disable on the Jackson com.fasterxml.jackson.databind.ObjectMapper.
setDisableFeatures(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Set of features to disable on the Jackson com.fasterxml.jackson.databind.ObjectMapper.
setDisableRedelivery(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Disables redelivery (same as setting maximum redeliveries to 0)
setDiscardOnCompletionTimeout(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setDiscardOnCompletionTimeout(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setDistributionRatio(String) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
The distribution ratio is a delimited String consisting on integer weights separated by delimiters for example "2,3,5".
setDistributionRatioDelimiter(String) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
Delimiter used to specify the distribution ratio.
setDnsDomain(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the DNS domain to use for DNS lookup.
setDocumentType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setDocumentType(Class<?>) - Method in class org.apache.camel.model.language.XPathExpression
Class for document type to use

The default value is org.w3c.dom.Document

setDocumentTypeName(String) - Method in class org.apache.camel.model.language.XPathExpression
Name of class for document type

The default value is org.w3c.dom.Document

setDomain(String) - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
The domain name;
setDontEncodeElements(Set<String>) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If provided, specifies the elements which should NOT be encoded.
setDontStripVersionsFromReferencesAtPaths(List<String>) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If supplied value(s), any resource references at the specified paths will have their resource versions encoded instead of being automatically stripped during the encoding process.
setDoWhile(Boolean) - Method in class org.apache.camel.model.LoopDefinition
Enables the while loop that loops until the predicate evaluates to false or null.
setDriver(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
To use a custom XStream driver.
setDriverRef(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
To refer to a custom XStream driver to lookup in the registry.
setDumperOptions(String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
DumperOptions to configure outgoing objects.
setDuration(long) - Method in class org.apache.camel.main.MainSupport
Sets the duration (in seconds) to run the application until it should be terminated.
setDurationHitExitCode(int) - Method in class org.apache.camel.main.MainSupport
Sets the exit code for the application if duration was hit
setDurationIdle(long) - Method in class org.apache.camel.main.MainSupport
Sets the maximum idle duration (in seconds) when running the application, and if there has been no message processed after being idle for more than this duration then the application should be terminated.
setDurationMaxMessages(int) - Method in class org.apache.camel.main.MainSupport
Sets the duration to run the application to process at most max messages until it should be terminated.
setDynamicUri(Boolean) - Method in class org.apache.camel.model.WireTapDefinition
 
setEager(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setEagerCheckCompletion(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setEagerCheckCompletion(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setElementNameStrategy(Object) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
Sets an element strategy instance to use.
setElementNameStrategyRef(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
Refers to an element strategy to lookup from the registry.
setEmptyValue(String) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The String representation of an empty value
setEnableCORS(Boolean) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Whether to enable CORS headers in the HTTP response.
setEnableCORS(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether to enable CORS headers in the HTTP response.
setEnableCORS(Boolean) - Method in class org.apache.camel.model.rest.RestDefinition
Whether to enable CORS headers in the HTTP response.
setEnableCORS(Boolean) - Method in class org.apache.camel.model.rest.VerbDefinition
Whether to enable CORS headers in the HTTP response.
setEnabled(boolean) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
setEnabled(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setEnableFeatures(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Set of features to enable on the Jackson com.fasterxml.jackson.databind.ObjectMapper.
setEnableFeatures(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Set of features to enable on the Jackson com.fasterxml.jackson.databind.ObjectMapper.
setEnableJaxbAnnotationModule(Boolean) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Whether to enable the JAXB annotations module when using jackson.
setEnableJaxbAnnotationModule(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Whether to enable the JAXB annotations module when using jackson.
setEncodeElements(Set<String>) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If provided, specifies the elements which should be encoded, to the exclusion of all others.
setEncodeElementsAppliesToChildResourcesOnly(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (default is false), the values supplied to FhirDataformat.setEncodeElements(Set) will not be applied to the root resource (typically a Bundle), but will be applied to any sub-resources contained within it (i.e.
setEncoding(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
The charset to use.
setEncoding(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To overrule and use a specific encoding
setEncoding(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
To overrule and use a specific encoding
setEncoding(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Sets the encoding to use
setEndpoint(Endpoint) - Method in class org.apache.camel.model.FromDefinition
 
setEndpoint(Endpoint) - Method in class org.apache.camel.model.SendDefinition
 
setEndpointProperties(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Allows to configure as many additional properties for the rest endpoint in use.
setEndToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setEndToken(String) - Method in class org.apache.camel.model.language.TokenizerExpression
The end token to use as tokenizer if using start/end token pairs.
setErrorHandler(String, Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setErrorHandler(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
setErrorHandler(AsyncProcessor) - Method in class org.apache.camel.processor.RoutingSlip
 
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.BuilderSupport
Sets the error handler to use with processors created by this builder
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.RouteBuilder
 
setErrorHandlerBuilder(ErrorHandlerFactory) - Method in class org.apache.camel.model.RouteDefinition
Sets the error handler to use with processors created by this builder
setErrorHandlerBuilderIfNull(ErrorHandlerFactory) - Method in class org.apache.camel.model.RouteDefinition
Sets the error handler if one is not already set
setErrorHandlerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setErrorHandlerFactory(ErrorHandlerFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setErrorHandlerFactory(ErrorHandlerFactory) - Method in class org.apache.camel.model.RoutesDefinition
 
setErrorHandlerRef(String) - Method in class org.apache.camel.model.RouteDefinition
Sets the bean ref name of the error handler builder to use on this route
setErrorHandlers(RouteContext, List<OnExceptionDefinition>) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Adds the error handlers for the given list of exception types
setErrorHandlers(RouteContext, List<OnExceptionDefinition>) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
setEscape(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the escape character to use
setEscapeChar(String) - Method in class org.apache.camel.model.dataformat.UniVocityTsvDataFormat
The escape character.
setEscapeDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Use for disabling using escape character
setEventFactory(EventFactory) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.DefaultProducerCache
Whether EventNotifier is enabled
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setExample(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
Sets the Swagger example
setExamples(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter examples.
setExamples(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
Examples of response messages
setException(Exception) - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
setExceptionClass(Class<? extends Exception>) - Method in class org.apache.camel.model.ThrowExceptionDefinition
The class of the exception to create using the message.
setExceptionClasses(List<Class<? extends Throwable>>) - Method in class org.apache.camel.model.CatchDefinition
 
setExceptionClasses(List<Class<? extends Throwable>>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.Resequencer
 
setExceptionPolicy(ExceptionPolicyStrategy) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Sets the strategy to use for resolving the OnExceptionDefinition to use for handling thrown exceptions.
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Sets the exception policy strategy to use for resolving the OnExceptionDefinition to use for a given thrown exception
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
setExceptions(List<String>) - Method in class org.apache.camel.model.CatchDefinition
 
setExceptions(List<String>) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
A list of class names for specific exceptions to monitor.
setExceptions(List<String>) - Method in class org.apache.camel.model.OnExceptionDefinition
A set of exceptions to react upon.
setExceptionType(String) - Method in class org.apache.camel.model.ThrowExceptionDefinition
The class of the exception to create using the message.
setExceptionTypes(List<Class<?>>) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
A list of specific exceptions to monitor.
setExchangeFormatterRef(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setExchangeFormatterRef(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.model.ProcessorDefinition
ExchangePattern: set the ExchangePattern into the Exchange.
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
SetExchangePatternDefinition - Class in org.apache.camel.model
Sets the exchange pattern on the message exchange
SetExchangePatternDefinition() - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
 
SetExchangePatternDefinition(ExchangePattern) - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
 
setExcludePattern(String) - Method in class org.apache.camel.model.RemoveHeadersDefinition
Name or patter of headers to not remove.
setExcludePattern(String) - Method in class org.apache.camel.model.RemovePropertiesDefinition
Name or pattern of properties to not remove.
setExcludePatterns(String[]) - Method in class org.apache.camel.model.RemoveHeadersDefinition
Name or pattern of headers to not remove.
setExcludePatterns(String[]) - Method in class org.apache.camel.model.RemovePropertiesDefinition
Name or pattern of properties to not remove.
setExcludes(List<String>) - Method in class org.apache.camel.model.ContextScanDefinition
Exclude finding route builder from these java package names.
setExcludes(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
Exclude finding route builder from these java package names.
setExecutionIsolationSemaphoreMaxConcurrentRequests(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Number of concurrent requests permitted to HystrixCommand.run().
setExecutionIsolationStrategy(String) - Method in class org.apache.camel.model.HystrixConfigurationCommon
What isolation strategy HystrixCommand.run() will be executed with.
setExecutionIsolationThreadInterruptOnTimeout(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether the execution thread should attempt an interrupt (using Future.cancel(boolean)) when a thread times out.
setExecutionTimeoutEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether the timeout mechanism is enabled for this command
setExecutionTimeoutInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Time in milliseconds at which point the command will timeout and halt execution.
setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.DelayDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.MulticastDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.RecipientListDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.SplitDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.ThreadsDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.ThrottleDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.WireTapDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.RecipientList
 
setExecutorServiceManager(ExecutorServiceManager) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setExecutorServiceRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.DelayDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.MulticastDefinition
Refers to a custom Thread Pool to be used for parallel processing.
setExecutorServiceRef(String) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.SplitDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.ThreadsDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.ThrottleDefinition
 
setExecutorServiceRef(String) - Method in class org.apache.camel.model.WireTapDefinition
 
setExpectedCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the expected number of message exchanges that should be received by this endpoint.
setExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
 
setExpectedMessageEndpoint(Endpoint) - Method in class org.apache.camel.component.test.TestEndpoint
 
setExponentialBackOff(Boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
setExponentialBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setExpression(Expression) - Method in class org.apache.camel.component.bean.ParameterInfo
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setExpression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Set a custom Expression to use.
setExpression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Set a custom Expression to use.
setExpression(Expression) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.DelayDefinition
Expression to define how long time to wait (in millis)
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.DynamicRouterDefinition
Expression to call that returns the endpoint(s) to route to in the dynamic routing.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.EnrichDefinition
Expression that computes the endpoint uri to use as the resource endpoint to enrich from
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionNode
 
setExpression(Expression) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.FilterDefinition
Expression to determine if the message should be filtered or not.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Expression used to calculate the correlation key to use for duplicate check.
setExpression(String) - Method in class org.apache.camel.model.language.ExpressionDefinition
The expression value in your chosen language syntax
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.LoopDefinition
Expression to define how many times we should loop.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.PollEnrichDefinition
Expression that computes the endpoint uri to use as the resource endpoint to enrich from
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.RecipientListDefinition
Expression that returns which endpoints (url) to send the message to (the recipients).
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ResequenceDefinition
Expression to use for re-ordering the messages, such as a header with a sequence number
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.RoutingSlipDefinition
Expression to define the routing slip, which defines which endpoints to route the message in a pipeline style.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SagaOptionDefinition
The expression to be used to determine the value of the option.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ScriptDefinition
Expression to return the transformed message body (the new message body to use)
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SetBodyDefinition
Expression that returns the new body to use
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SetFaultBodyDefinition
Expression that returns the new fault body to use
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SetHeaderDefinition
Expression to return the value of the header
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SetPropertyDefinition
Expression to return the value of the message exchange property
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SortDefinition
Optional expression to sort by something else than the message body
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.SplitDefinition
Expression of how to split the message body, such as as-is, using a tokenizer, or using an xpath.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ThrottleDefinition
Expression to configure the maximum number of messages to throttle per request
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.TransformDefinition
Expression to return the transformed message body (the new message body to use)
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ValidateDefinition
Expression to use for validation as a predicate.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.validator.PredicateValidatorDefinition
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.WhenDefinition
Expression used as the predicate to evaluate whether this when should trigger and route the message or not.
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.WhenSkipSendToEndpointDefinition
Expression used as the predicate to evaluate whether the message should be sent or not to the endpoint
setExpression(Expression) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
setExpression(Expression) - Method in interface org.apache.camel.processor.resequencer.ExpressionResultComparator
Set the expression used for comparing Exchanges.
setExpressionConfiguration(ServiceCallExpressionConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the Expression using the given configuration.
setExpressionConfiguration(ServiceCallExpressionConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the Expression using the given configuration.
setExpressionRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Set a reference to a custom Expression to use.
setExpressionRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Set a reference to a custom Expression to use.
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.builder.ExpressionClause
 
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
 
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.language.ExpressionDefinition
Allows derived classes to set a lazily created expressionType instance such as if using the ExpressionClause
setExpressionValue(Expression) - Method in class org.apache.camel.builder.ExpressionClause
 
setExpressionValue(Expression) - Method in class org.apache.camel.builder.ExpressionClauseSupport
 
setExpressionValue(Expression) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
setExtendedStatistics(boolean) - Method in class org.apache.camel.impl.DefaultConsumerCache
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
setExtendedStatistics(boolean) - Method in class org.apache.camel.impl.DefaultProducerCache
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
setExtension(Class<T>, T) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setFactoryClassName(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setFactoryFinderResolver(FactoryFinderResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setFactoryRef(String) - Method in class org.apache.camel.model.language.XPathExpression
References to a custom XPathFactory to lookup in the registry
setFailed(int) - Method in class org.apache.camel.impl.ReloadStrategySupport
 
setFailureProcessor(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setFallbackEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether HystrixCommand.getFallback() should be attempted when failure occurs.
setFallbackIsolationSemaphoreMaxConcurrentRequests(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Number of concurrent requests permitted to HystrixCommand.getFallback().
setFallbackTimeout(long) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setFallbackViaNetwork(Boolean) - Method in class org.apache.camel.model.OnFallbackDefinition
Whether the fallback goes over the network.
setFaultBody(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the body on the FAULT message
SetFaultBodyDefinition - Class in org.apache.camel.model
Sets the contents of a fault message's body
SetFaultBodyDefinition() - Constructor for class org.apache.camel.model.SetFaultBodyDefinition
 
SetFaultBodyDefinition(Expression) - Constructor for class org.apache.camel.model.SetFaultBodyDefinition
 
setFhirContext(Object) - Method in class org.apache.camel.model.dataformat.FhirDataformat
 
setFhirVersion(String) - Method in class org.apache.camel.model.dataformat.FhirDataformat
The version of FHIR to use.
setFields(String[]) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
setFields(String[]) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
setFileStore(File) - Method in class org.apache.camel.impl.FileStateRepository
 
setFileWatchDirectory(String) - Method in class org.apache.camel.main.MainSupport
Sets the directory name to watch XML file changes to trigger live reload of Camel routes.
setFileWatchDirectoryRecursively(boolean) - Method in class org.apache.camel.main.MainSupport
Sets the flag to watch directory of XML file changes recursively to trigger live reload of Camel routes.
setFilter(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setFilterNonXmlChars(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To ignore non xml characheters and replace them with an empty space.
setFilters(Collection<ClusteredRouteFilter>) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Sets the filters used to filter cluster aware routes.
setFilters(Collection<SupervisingRouteController.Filter>) - Method in class org.apache.camel.impl.SupervisingRouteController
Sets the filters user to determine the routes to supervise.
setFixed(Boolean) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
Delimited or fixed.
setFlow(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
The flow used by the OAuth2 security scheme.
setFolder(String) - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
setForceCompletionOnStop(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setForceCompletionOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setForceResourceId(Object) - Method in class org.apache.camel.model.dataformat.FhirDataformat
When encoding, force this resource ID to be encoded as the resource ID
setFormatName(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
The name of the format to use, the default value is CSVFormat.DEFAULT
setFormatRef(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
The reference format to use, it will be updated with the other format options, the default value is CSVFormat.DEFAULT
setFragment(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To turn on marshalling XML fragment trees.
setFromRouteId(String) - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
Limit the route policy to the route which matches this pattern
setFromType(String) - Method in class org.apache.camel.model.transformer.TransformerDefinition
Set the 'from' data type name.
setFromType(Class<?>) - Method in class org.apache.camel.model.transformer.TransformerDefinition
Set the 'from' data type using Java class.
setFunctionEndToken(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
Change the end token used for functions.
setFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setFunctionStartToken(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
Change the start token used for functions.
setGlobalOptions(Map<String, String>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setGlobalOptions(List<GlobalOptionDefinition>) - Method in class org.apache.camel.model.GlobalOptionsDefinition
A series of global options as key value pairs
setGroup(int) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
setGroup(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setGroup(int) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
setGroup(String) - Method in class org.apache.camel.model.language.TokenizerExpression
To group N parts together, for example to split big files into chunks of 1000 lines.
setGroup(Integer) - Method in class org.apache.camel.model.language.XMLTokenizerExpression
To group N parts together
setGroup(String) - Method in class org.apache.camel.model.RouteDefinition
The group that this route belongs to; could be the name of the RouteBuilder class or be explicitly configured in the XML.
setGroupExchanges(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setGroupKey(String) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Sets the group key to use.
setHandled(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setHandledPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setHandleFault(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setHandleFault(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setHandleFault(String) - Method in class org.apache.camel.model.RouteDefinition
Whether handle fault is enabled on this route.
setHashAlgorithm(Integer) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Signature hash algorithm; possible values are defined in org.bouncycastle.bcpg.HashAlgorithmTags; for example 2 (= SHA1), 8 (= SHA256), 9 (= SHA384), 10 (= SHA512), 11 (=SHA224).
setHeader(List<String>) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
To configure the CSV headers
setHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the header on the IN message
setHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the header on the IN message
setHeader(String, Supplier<Object>) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the header on the IN message
SetHeaderDefinition - Class in org.apache.camel.model
Sets the value of a message header
SetHeaderDefinition() - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, String) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
setHeaderDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
 
setHeaderExtractionEnabled(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether or not the header must be read in the first line of the test document

The default value is false

setHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setHeaderName(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setHeaderName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setHeaderName(String) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
setHeaderName(String) - Method in class org.apache.camel.model.language.JsonPathExpression
Name of header to use as input, instead of the message body
setHeaderName(String) - Method in class org.apache.camel.model.language.TokenizerExpression
Name of header to tokenize instead of using the message body.
setHeaderName(String) - Method in class org.apache.camel.model.language.XMLTokenizerExpression
Name of header to tokenize instead of using the message body.
setHeaderName(String) - Method in class org.apache.camel.model.language.XPathExpression
Name of header to use as input, instead of the message body
setHeaderName(String) - Method in class org.apache.camel.model.language.XQueryExpression
Name of header to use as input, instead of the message body
setHeaderName(String) - Method in class org.apache.camel.model.RemoveHeaderDefinition
Name of header to remove
setHeaderName(String) - Method in class org.apache.camel.model.SetHeaderDefinition
Name of message header to set a new value

The simple language can be used to define a dynamic evaluated header name to be used.

SetHeaderProcessor - Class in org.apache.camel.processor
A processor which sets the header on the IN or OUT message with an Expression
SetHeaderProcessor(Expression, Expression) - Constructor for class org.apache.camel.processor.SetHeaderProcessor
 
setHeaders(List<UniVocityHeader>) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The headers to use.
setHeaders(List<RestOperationResponseHeaderDefinition>) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
setHeaders(List<SetHeaderDefinition>) - Method in class org.apache.camel.model.WireTapDefinition
 
setHeadersDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether or not the headers are disabled.
setHeadersInline(Boolean) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
Defines whether the MIME-Multipart headers are part of the message body (true) or are set as Camel headers (false).
setHeadersMapFactory(HeadersMapFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setHeight(Integer) - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
Height of the barcode
setHost(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
The hostname to use for exposing the REST service.
setHostHeader(String) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
The header that holds the service host information, default ServiceCallConstants.SERVICE_HOST
setHostNameResolver(RestHostNameResolver) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
If no hostname has been explicit configured, then this resolver is used to compute the hostname the REST service will be using.
setHystrixConfiguration(HystrixConfigurationDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setHystrixConfiguration(HystrixConfigurationDefinition) - Method in class org.apache.camel.model.HystrixDefinition
 
setHystrixConfiguration(HystrixConfigurationDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the default Hystrix configuration
setHystrixConfigurationRef(String) - Method in class org.apache.camel.model.HystrixDefinition
Refers to a Hystrix configuration to use for configuring the Hystrix EIP.
setHystrixConfigurations(List<HystrixConfigurationDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setHystrixConfigurations(List<HystrixConfigurationDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the Hystrix configurations
setId(String) - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
setId(String) - Method in class org.apache.camel.model.ChoiceDefinition
 
setId(String) - Method in class org.apache.camel.model.IdentifiedType
Sets the value of the id property.
setId(String) - Method in class org.apache.camel.model.language.ExpressionDefinition
Sets the id of this node
setId(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the id of this node
setId(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setId(String) - Method in class org.apache.camel.processor.CatchProcessor
 
setId(String) - Method in class org.apache.camel.processor.ChoiceProcessor
 
setId(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setId(String) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
setId(String) - Method in class org.apache.camel.processor.Delayer
 
setId(String) - Method in class org.apache.camel.processor.Enricher
 
setId(String) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setId(String) - Method in class org.apache.camel.processor.FilterProcessor
 
setId(String) - Method in class org.apache.camel.processor.FinallyProcessor
 
setId(String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
setId(String) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
setId(String) - Method in class org.apache.camel.processor.LogProcessor
 
setId(String) - Method in class org.apache.camel.processor.LoopProcessor
 
setId(String) - Method in class org.apache.camel.processor.MulticastProcessor
 
setId(String) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
setId(String) - Method in class org.apache.camel.processor.Pipeline
 
setId(String) - Method in class org.apache.camel.processor.PollEnricher
 
setId(String) - Method in class org.apache.camel.processor.RecipientList
 
setId(String) - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
setId(String) - Method in class org.apache.camel.processor.Resequencer
 
setId(String) - Method in class org.apache.camel.processor.RollbackProcessor
 
setId(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setId(String) - Method in class org.apache.camel.processor.SamplingThrottler
 
setId(String) - Method in class org.apache.camel.processor.ScriptProcessor
 
setId(String) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setId(String) - Method in class org.apache.camel.processor.SendProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetBodyProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
setId(String) - Method in class org.apache.camel.processor.SortProcessor
 
setId(String) - Method in class org.apache.camel.processor.StopProcessor
 
setId(String) - Method in class org.apache.camel.processor.StreamResequencer
 
setId(String) - Method in class org.apache.camel.processor.ThreadsProcessor
 
setId(String) - Method in class org.apache.camel.processor.Throttler
 
setId(String) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setId(String) - Method in class org.apache.camel.processor.TransformProcessor
 
setId(String) - Method in class org.apache.camel.processor.TryProcessor
 
setId(String) - Method in class org.apache.camel.processor.WireTapProcessor
 
setIgnoreEmptyLines(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether to ignore empty lines.
setIgnoreExtraColumns(Boolean) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
Allows for lines to be longer than expected and ignores the extra characters.
setIgnoreFirstRecord(Boolean) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
Whether the first line is ignored for delimited files (for the column headers).
setIgnoreHeaderCase(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets whether or not to ignore case when accessing header names.
setIgnoreInvalidCorrelationKeys(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setIgnoreInvalidCorrelationKeys(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setIgnoreInvalidEndpoint(Boolean) - Method in class org.apache.camel.model.EnrichDefinition
 
setIgnoreInvalidEndpoint(Boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setIgnoreInvalidEndpoint(Boolean) - Method in class org.apache.camel.model.ToDynamicDefinition
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.Enricher
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.PollEnricher
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.DynamicRouterDefinition
 
setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientListProcessor
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RoutingSlip
 
setIgnoreInvalidExchanges(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
Whether to ignore invalid exchanges
setIgnoreInvalidExchanges(Boolean) - Method in class org.apache.camel.model.config.StreamResequencerConfig
Whether to ignore invalid exchanges
setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.StreamResequencer
Sets whether to ignore invalid exchanges which cannot be used by this stream resequencer.
setIgnoreInvalidRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
Whether to ignore invalid records.
setIgnoreJAXBElement(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Whether to ignore JAXBElement elements - only needed to be set to false in very special use-cases.
setIgnoreLeadingWhitespaces(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether or not the leading white spaces must be ignored.
setIgnoreSurroundingSpaces(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether to ignore surrounding spaces
setIgnoreTrailingWhitespaces(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether or not the trailing white spaces must ignored.
setIgnoreUnexpectedRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
Whether to ignore unexpected records.
setIgnoreUnidentifiedRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
Whether to ignore unidentified records.
setImageType(String) - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
Image type of the barcode such as png
setImplicitCollections(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Adds a default implicit collection which is used for any unmapped XML tag.
setInclude(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
If you want to marshal a pojo to JSON, and the pojo has some fields with null values.
setInclude(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
If you want to marshal a pojo to JSON, and the pojo has some fields with null values.
setIncludeHeaders(String) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
A regex that defines which Camel headers are also included as MIME headers into the MIME multipart.
setIncludeNonSingletons(Boolean) - Method in class org.apache.camel.model.ContextScanDefinition
Whether to include non-singleton beans (prototypes)

By default only singleton beans is included in the context scan

setIncludes(List<String>) - Method in class org.apache.camel.model.ContextScanDefinition
Include finding route builder from these java package names.
setIncludes(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
Include finding route builder from these java package names.
setIncludeTokens(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setIncludeTokens(Boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
Whether to include the tokens in the parts when using pairs

The default value is false

setInflightRepository(InflightRepository) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setInHeader(Boolean) - Method in class org.apache.camel.model.rest.RestSecurityApiKey
To use header as the location of the API key.
setInheritErrorHandler(Boolean) - Method in class org.apache.camel.model.ProcessorDefinition
 
setInheritNamespaceTagName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setInheritNamespaceTagName(String) - Method in class org.apache.camel.model.language.TokenizerExpression
To inherit namespaces from a root/parent tag name when using XML You can use simple language as the tag name to support dynamic names.
setInitialDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Time period in millis to wait before starting sending messages.
setInitialDelay(Duration) - Method in class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
setInitialDelay(Duration) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Set the amount of time the route controller should wait before to start the routes after the camel context is started.
setInitialDelay(Duration) - Method in class org.apache.camel.impl.cluster.ClusteredRoutePolicy
 
setInitialDelay(Duration) - Method in class org.apache.camel.impl.SupervisingRouteController
Set the amount of time the route controller should wait before to start the routes after the camel context is started or after the route is initialized if the route is created after the camel context is started.
setInitialDelay(long, TimeUnit) - Method in class org.apache.camel.impl.SupervisingRouteController
#see this#setInitialDelay(Duration)
setInitialDelay(long) - Method in class org.apache.camel.impl.SupervisingRouteController
#see this#setInitialDelay(Duration)
setInitialization(AbstractCamelContext.Initialization) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setInitialProperties(Properties) - Method in class org.apache.camel.main.MainSupport
Sets initial properties for the properties component, which will be used before any locations are resolved.
setInitVectorRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
Refers to a byte array containing the Initialization Vector that will be used to initialize the Cipher.
setInjector(Injector) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setInline(Boolean) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
Flag indicating that the configured IV should be inlined into the encrypted data stream.
setInput(FromDefinition) - Method in class org.apache.camel.model.RouteDefinition
Input to the route.
setInputType(InputTypeDefinition) - Method in class org.apache.camel.model.RouteDefinition
 
setInQuery(Boolean) - Method in class org.apache.camel.model.rest.RestSecurityApiKey
To use query parameter as the location of the API key.
setInstance(Object) - Method in class org.apache.camel.model.language.MethodCallExpression
 
setInstanceClass(String) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
Name of class to use when unarmshalling
setInstanceClass(String) - Method in class org.apache.camel.model.dataformat.ThriftDataFormat
Name of class to use when unarmshalling
setInstanceClassName(String) - Method in class org.apache.camel.model.dataformat.AvroDataFormat
Class name to use for marshal and unmarshalling
setIntegrity(Boolean) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Adds an integrity check/sign into the encryption file.
setInterceptFroms(List<InterceptFromDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setIntercepts(List<InterceptDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setInterceptSendTos(List<InterceptSendToEndpointDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setInterruptThreadsWhileStopping(boolean) - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
setIsRouteAdded(boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setJavaClass(Class<?>) - Method in class org.apache.camel.model.InputTypeDefinition
Set input type via Java Class.
setJavaClass(Class<?>) - Method in class org.apache.camel.model.OutputTypeDefinition
Set output type via Java Class.
setJaxbProviderProperties(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Refers to a custom java.util.Map to lookup in the registry containing custom JAXB provider properties to be used with the JAXB marshaller.
setJsonDataFormat(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Name of specific json data format to use.
setJsonView(Class<?>) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
When marshalling a POJO to JSON you might want to exclude certain fields from the JSON output.
setJsonView(Class<?>) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
When marshalling a POJO to JSON you might want to exclude certain fields from the JSON output.
setKeepAliveTime(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Keep-alive time in minutes that gets passed to ThreadPoolExecutor.setKeepAliveTime(long, TimeUnit)
setKeepAliveTime(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the keep alive time for idle threads in the pool
setKeepAliveTime(Long) - Method in class org.apache.camel.model.ThreadsDefinition
 
setKey(String) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setKey(String) - Method in class org.apache.camel.model.GlobalOptionDefinition
Global option key
setKey(String) - Method in class org.apache.camel.model.PropertyDefinition
Property key
setKey(String) - Method in class org.apache.camel.model.rest.RestPropertyDefinition
Property key
setKey(String) - Method in class org.apache.camel.model.rest.RestSecurityDefinition
Key used to refer to this security definition
setKey(String) - Method in class org.apache.camel.model.rest.SecurityDefinition
Key used to refer to this security definition
setKey(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setKeyCipherAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The cipher algorithm to be used for encryption/decryption of the asymmetric key.
setKeyFileName(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Filename of the keyring; must be accessible as a classpath resource (but you can specify a location in the file system by using the "file:" prefix).
setKeyOrTrustStoreParameters(KeyStoreParameters) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
Configuration options for creating and loading a KeyStore instance that represents the sender's trustStore or recipient's keyStore.
setKeyOrTrustStoreParametersRef(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
Refers to a KeyStore instance to lookup in the registry, which is used for configuration options for creating and loading a KeyStore instance that represents the sender's trustStore or recipient's keyStore.
setKeyPassword(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The password to be used for retrieving the private key from the KeyStore.
setKeyRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
Refers to the secret key to lookup from the register to use.
setKeyUserid(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
The user ID of the key in the PGP keyring used during encryption.
setLang(String) - Method in class org.apache.camel.model.DescriptionDefinition
Language, such as en for english.
setLanguage(String) - Method in class org.apache.camel.model.language.LanguageExpression
The name of the language to use
setLanguageResolver(LanguageResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setLastError(RouteError) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setLazyLoad(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether the unmarshalling should produce an iterator that reads the lines on the fly or if all the lines must be read at one.
setLazyLoad(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether the unmarshalling should produce an iterator that reads the lines on the fly or if all the lines must be read at one.
setLength(Integer) - Method in class org.apache.camel.model.dataformat.UniVocityHeader
Header length
setLibrary(JsonLibrary) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Which json library to use.
setLibrary(YAMLLibrary) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Which yaml library to use.
setLimit(int) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
setLimit(int) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
Sets the limit for how many straight rollbacks causes this strategy to suspend the fault consumer.
setLineLength(Integer) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
To specific a maximum line length for the encoded data.
setLineSeparator(String) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
The line separators to use.
setLineSeparator(String) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The line separator of the files

The default value is to use the JVM platform line separator

setList(List<XStreamDataFormat.AliasEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasList
 
setList(List<XStreamDataFormat.ConverterEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterList
 
setList(List<XStreamDataFormat.ImplicitCollectionEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionList
 
setList(List<XStreamDataFormat.OmitFieldEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldList
 
setLoadBalancer(ServiceLoadBalancer) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceLoadBalancer to use.
setLoadBalancer(ServiceLoadBalancer) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceLoadBalancer to use.
setLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
setLoadBalancerConfiguration(ServiceCallServiceLoadBalancerConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures theL oadBalancer using the given configuration.
setLoadBalancerConfiguration(ServiceCallServiceLoadBalancerConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the LoadBalancer using the given configuration.
setLoadBalancerRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceLoadBalancer to use.
setLoadBalancerRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceLoadBalancer to use.
setLoadBalancerType(LoadBalancerDefinition) - Method in class org.apache.camel.model.LoadBalanceDefinition
The load balancer to be used
setLoadTypeConverters(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setLocale(String) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
To configure a default locale to use, such as us for united states.
setLogContinued(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogContinued(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether errors should be logged even if its continued
setLogExhausted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogExhausted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether exhausted exceptions should be logged or not
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setLogExhaustedMessageBody(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether exhausted message body/headers should be logged with message history included (requires logExhaustedMessageHistory to be enabled).
setLogExhaustedMessageHistory(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether exhausted exceptions should be logged with message history included.
setLogger(CamelLogger) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setLogger(Logger) - Method in class org.apache.camel.model.LogDefinition
To use a custom logger instance
setLoggerRef(String) - Method in class org.apache.camel.model.LogDefinition
To refer to a custom logger instance to lookup from the registry.
setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.model.LogDefinition
Sets the logging level.
setLoggingLevel(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setLogHandled(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogHandled(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether errors should be logged even if its handled
setLogInflightExchangesOnTimeout(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setLogMask(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setLogMask(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setLogMask(String) - Method in class org.apache.camel.model.RouteDefinition
Whether security mask for Logging is enabled on this route.
setLogName(String) - Method in class org.apache.camel.model.LogDefinition
Sets the name of the logger
setLogNamespaces(boolean) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setLogNamespaces(Boolean) - Method in class org.apache.camel.model.language.XPathExpression
Whether to log namespaces which can assist during trouble shooting
setLogNewException(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogNewException(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether errors should be logged when a new exception occurred during handling a previous exception
setLogRetryAttempted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogRetryAttempted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether retry attempts should be logged or not
setLogRetryStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogRetryStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether stack traces should be logged or not
setLogStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets whether stack traces should be logged or not
setLookup(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
How to perform service lookup.
setMacAlgorithm(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
The JCE algorithm name indicating the Message Authentication algorithm.
setManagementAgent(ManagementAgent) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
setManagementInterceptStrategy(ManagementInterceptStrategy) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setManagementMBeanAssembler(ManagementMBeanAssembler) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setManagementName(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setManagementNameStrategy(ManagementNameStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setManagementObjectNameStrategy(ManagementObjectNameStrategy) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
setManagementObjectStrategy(ManagementObjectStrategy) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
setManagementStrategy(ManagementStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setMapping(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
The BeanIO mapping file.
setMarker(String) - Method in class org.apache.camel.model.LogDefinition
To use slf4j marker
setMarkRollbackOnly(Boolean) - Method in class org.apache.camel.model.RollbackDefinition
Mark the transaction for rollback only (cannot be overruled to commit)
setMarkRollbackOnly(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMarkRollbackOnlyLast(Boolean) - Method in class org.apache.camel.model.RollbackDefinition
Mark only last sub transaction for rollback only.
setMarkRollbackOnlyLast(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMarshallerFactoryRef(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the implementation of the CsvMarshallerFactory interface which is able to customize marshalling/unmarshalling behavior by extending CsvMarshaller or creating it from scratch.
setMasterUrl(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the URL to the master when using client lookup
setMaxFileStoreSize(long) - Method in class org.apache.camel.impl.FileStateRepository
Sets the maximum file size for the file store in bytes.
setMaximumCacheSize(int) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
setMaximumCacheSize(int) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
setMaximumCacheSize(int) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setMaximumFailoverAttempts(Integer) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
A value to indicate after X failover attempts we should exhaust (give up).
setMaximumFailoverAttempts(int) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setMaximumRedeliveries(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered.
setMaximumRedeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setMaximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum redelivery delay.
setMaximumRequestsPerPeriodExpression(Expression) - Method in class org.apache.camel.processor.Throttler
Sets the maximum number of requests per time period expression
setMaximumRetries(Integer) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
setMaximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMaximumRetryDelay(Long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
setMaximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMaximumSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Maximum thread-pool size that gets passed to ThreadPoolExecutor.setMaximumPoolSize(int).
setMaxMessages(int) - Method in class org.apache.camel.impl.DurationRoutePolicy
Maximum number of messages to process before the action is triggered
setMaxMessages(int) - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
Maximum number of messages to process before the action is triggered
setMaxPoolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the maximum pool size
setMaxPoolSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
 
setMaxQueueSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Max queue size that gets passed to BlockingQueue in HystrixConcurrencyStrategy.getBlockingQueue(int) This should only affect the instantiation of a threadpool - it is not eliglible to change a queue size on the fly.
setMaxQueueSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the maximum number of tasks in the work queue.
setMaxQueueSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
 
setMaxSeconds(int) - Method in class org.apache.camel.impl.DurationRoutePolicy
Maximum seconds Camel is running before the action is triggered
setMaxSeconds(int) - Method in class org.apache.camel.impl.DurationRoutePolicyFactory
Maximum seconds Camel is running before the action is triggered
setMessage(String) - Method in class org.apache.camel.model.LogDefinition
Sets the log message (uses simple language)
setMessage(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
setMessage(String) - Method in class org.apache.camel.model.RollbackDefinition
Message to use in rollback exception
setMessage(String) - Method in class org.apache.camel.model.ThrowExceptionDefinition
To create a new exception instance and use the given message as caused message (supports simple language)
setMessageBodyOnBreakpoint(String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageBodyOnBreakpoint(String, Object, Class<?>) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageFrequency(Long) - Method in class org.apache.camel.model.SamplingDefinition
Sets the sample message count which only a single Exchange will pass through after this many received.
setMessageHeaderOnBreakpoint(String, String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageHeaderOnBreakpoint(String, String, Object, Class<?>) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageHistory(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setMessageHistory(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setMessageHistory(String) - Method in class org.apache.camel.model.RouteDefinition
Whether message history is enabled on this route.
setMessageHistoryFactory(MessageHistoryFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setMessageIdRepository(IdempotentRepository) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setMessageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setMethod(String) - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
Sets the method name to use
setMethod(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
Sets the name of the method to invoke on the bean
setMethod(Method) - Method in class org.apache.camel.component.bean.BeanInvocation
 
setMethod(String) - Method in class org.apache.camel.component.bean.BeanProcessor
 
setMethod(String) - Method in class org.apache.camel.model.BeanDefinition
Sets the method name on the bean to use
setMethod(String) - Method in class org.apache.camel.model.language.MethodCallExpression
Name of method to call
setMethod(String) - Method in class org.apache.camel.model.rest.VerbDefinition
The HTTP verb such as GET, POST, DELETE, etc.
setMethodName(String) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setMetricsHealthSnapshotIntervalInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Time in milliseconds to wait between allowing health snapshots to be taken that calculate success and error percentages and affect HystrixCircuitBreaker.isOpen() status.
setMetricsRollingPercentileBucketSize(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Maximum number of values stored in each bucket of the rolling percentile.
setMetricsRollingPercentileEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether percentile metrics should be captured using HystrixRollingPercentile inside HystrixCommandMetrics.
setMetricsRollingPercentileWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Number of buckets the rolling percentile window is broken into.
setMetricsRollingPercentileWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Duration of percentile rolling window in milliseconds.
setMetricsRollingStatisticalWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Number of buckets the rolling statistical window is broken into.
setMetricsRollingStatisticalWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
This property sets the duration of the statistical rolling window, in milliseconds.
setMgfAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The MGF Algorithm to use with the RSA OAEP algorithm.
setMinimumExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the minimum number of expected message exchanges that should be received by this endpoint
setMinRate(int) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Wait until the DataSet contains at least this number of messages
setMode(char) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
setMode(String) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
setMode(char) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
setMode(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Mode for dealing with duplicate references The possible values are: NO_REFERENCES ID_REFERENCES XPATH_RELATIVE_REFERENCES XPATH_ABSOLUTE_REFERENCES SINGLE_NODE_XPATH_RELATIVE_REFERENCES SINGLE_NODE_XPATH_ABSOLUTE_REFERENCES
setMode(String) - Method in class org.apache.camel.model.language.XMLTokenizerExpression
The extraction mode.
setMode(OnCompletionMode) - Method in class org.apache.camel.model.OnCompletionDefinition
Sets the on completion mode.
setModelJAXBContextFactory(ModelJAXBContextFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setModuleClassNames(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
To use custom Jackson modules com.fasterxml.jackson.databind.Module specified as a String with FQN class names.
setModuleClassNames(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
To use custom Jackson modules com.fasterxml.jackson.databind.Module specified as a String with FQN class names.
setModuleRefs(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
To use custom Jackson modules referred from the Camel registry.
setModuleRefs(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
To use custom Jackson modules referred from the Camel registry.
setMultipartSubType(String) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
Specify the subtype of the MIME Multipart.
setMultipartWithoutAttachment(Boolean) - Method in class org.apache.camel.model.dataformat.MimeMultipartDataFormat
Defines whether a message without attachment is also marshaled into a MIME Multipart (with only one body part).
setMustBeJAXBElement(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Whether marhsalling must be java objects with JAXB annotations.
setName(String) - Method in class org.apache.camel.component.bean.MethodBean
 
setName(String) - Method in class org.apache.camel.component.mock.MockEndpoint
 
setName(String) - Method in class org.apache.camel.impl.AbstractCamelContext
Sets the name of the this context.
setName(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the name of the service to use
setName(String) - Method in class org.apache.camel.model.dataformat.UniVocityHeader
Header name
setName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
setName(String) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter name.
setName(String) - Method in class org.apache.camel.model.rest.RestOperationResponseHeaderDefinition
 
setName(String) - Method in class org.apache.camel.model.rest.RestSecurityApiKey
The name of the header or query parameter to be used.
setNamePattern(String) - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
 
setNamespace(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteConfiguration
 
setNamespace(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Set the default namespace.
setNamespace(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the namespace to use.
setNamespace(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
The namespace
setNamespace(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
As ZooKeeper is a shared space, users of a given cluster should stay within a pre-defined namespace.
setNamespaceContext(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespaceIfNotPresent(DefaultNamespaceContext, String, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespacePrefixRef(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
When marshalling using JAXB or SOAP then the JAXB implementation will automatic assign namespace prefixes, such as ns2, ns3, ns4 etc.
setNamespacePrefixRef(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
When marshalling using JAXB or SOAP then the JAXB implementation will automatic assign namespace prefixes, such as ns2, ns3, ns4 etc.
setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.XMLTokenExpressionIterator
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
Injects the XML Namespaces of prefix -> uri mappings
setNameStrategy(CamelContextNameStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setNewExchangeExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.WireTapDefinition
Uses the expression for creating a new body as the message to use for wire tapping
setNewExchangeExpression(Expression) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNewExchangeProcessor(Processor) - Method in class org.apache.camel.model.WireTapDefinition
To use a Processor for creating a new body as the message to use for wire tapping
setNewExchangeProcessorRef(String) - Method in class org.apache.camel.model.WireTapDefinition
Reference to a Processor to use for creating a new body as the message to use for wire tapping
setNewExchangeProcessors(List<Processor>) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNextProcessor(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
setNodeIdFactory(NodeIdFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setNodes(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
A comma separate list of servers to connect to in the form host:port
setNoNamespaceSchemaLocation(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To define the location of the namespaceless schema
setNormalizedLineSeparator(String) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The normalized line separator of the files

The default value is a new line character.

setNullString(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the null string
setNullStringDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Used to disable null strings
setNullValue(String) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The string representation of a null value.
setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setNumberOfRecordsToRead(Integer) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
The maximum number of record to read.
setOauthToken(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the OAUTH token for authentication (instead of username/password) when using client lookup
setObjectFactory(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Whether to allow using ObjectFactory classes to create the POJO classes during marshalling.
setObjectMapper(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Lookup and use the existing ObjectMapper with the given id when using Jackson.
setObjectModel(String) - Method in class org.apache.camel.model.language.XPathExpression
The XPath object model to use
setObjectModelUri(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setObjectModelUri(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
setOmitFields(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Prevents a field from being serialized.
setOmitResourceId(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (default is false) the ID of any resources being encoded will not be included in the output.
setOmitXmlDeclaration(Boolean) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
When returning a String, do we omit the XML declaration in the top.
setOnCompleteOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnCompletion(String, Processor) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnCompletions(List<OnCompletionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setOnExceptionOccurred(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setOnExceptionOccurred(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnExceptionOccurredRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnExceptions(List<OnExceptionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setOnFailureOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnFallback(OnFallbackDefinition) - Method in class org.apache.camel.model.HystrixDefinition
 
setOnPrepare(Processor) - Method in class org.apache.camel.model.MulticastDefinition
 
setOnPrepare(Processor) - Method in class org.apache.camel.model.RecipientListDefinition
 
setOnPrepare(Processor) - Method in class org.apache.camel.model.SplitDefinition
 
setOnPrepare(Processor) - Method in class org.apache.camel.model.WireTapDefinition
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.RecipientList
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
setOnPrepareFailure(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setOnPrepareRef(String) - Method in class org.apache.camel.model.MulticastDefinition
 
setOnPrepareRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
 
setOnPrepareRef(String) - Method in class org.apache.camel.model.SplitDefinition
 
setOnPrepareRef(String) - Method in class org.apache.camel.model.WireTapDefinition
 
setOnRedelivery(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setOnRedelivery(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnRedeliveryRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.CatchDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOperation(ClaimCheckOperation) - Method in class org.apache.camel.model.ClaimCheckDefinition
 
setOperation(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setOptimisticLocking(boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setOptimisticLocking(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockingExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.model.AggregateDefinition
 
setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockRetryPolicyDefinition(OptimisticLockRetryPolicyDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setOptionName(String) - Method in class org.apache.camel.model.SagaOptionDefinition
Name of the option.
setOptions(List<SagaOptionDefinition>) - Method in class org.apache.camel.model.SagaDefinition
Allows to save properties of the current exchange in order to re-use them in a compensation/completion callback route.
setOrder(int) - Method in class org.apache.camel.impl.cloud.AbstractServiceRegistry
 
setOriginalRoute(RouteDefinition) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Sets the original route to be adviced.
setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.config.ResequencerConfig
 
setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.DataFormatDefinition
Adds an optional attribute
setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
setOtherAttributes(Map<QName, Object>) - Method in interface org.apache.camel.model.OtherAttributesAware
Adds optional attribute to use as property placeholder
setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.ProcessorDefinition
 
setOtherwise(OtherwiseDefinition) - Method in class org.apache.camel.model.ChoiceDefinition
 
setOutBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the out batch size.
setOutBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutput(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.AggregateDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.CatchDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.ExpressionNode
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.HystrixDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.LoadBalanceDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OutputDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.ResequenceDefinition
 
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.RouteDefinition
Outputs are processors that determines how messages are processed by this route.
setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.TryDefinition
 
setOutputTransformer(Processor) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setOutputType(OutputTypeDefinition) - Method in class org.apache.camel.model.RouteDefinition
 
setOutType(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Sets the class name to use for binding from POJO to output for the outgoing data

The canonical name of the class of the input data.

setOutType(String) - Method in class org.apache.camel.model.rest.VerbDefinition
Sets the class name to use for binding from POJO to output for the outgoing data This option will override what may be configured on a parent level

The canonical name of the class of the input data.

setOverrideProperties(Properties) - Method in class org.apache.camel.main.MainSupport
Sets a special list of override properties that take precedence and will use first, if a property exist.
setOverrideResourceIdWithBundleEntryFullUrl(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (which is the default), the Bundle.entry.fullUrl will override the Bundle.entry.resource's resource id if the fullUrl is defined.
setPackages(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
Sets the java package names to use for scanning for route builder classes
setPackageScanClassResolver(PackageScanClassResolver) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setPadding(String) - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
The padding character.
setParallelAggregate(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setParallelAggregate(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setParallelAggregate(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setParallelAggregate(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setParallelProcessing(boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setParallelProcessing(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setParallelProcessing(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setParallelProcessing(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setParallelProcessing(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setParameterMappingStrategy(ParameterMappingStrategy) - Method in class org.apache.camel.component.bean.RegistryBean
 
setParameters(Map<String, Object>) - Method in class org.apache.camel.component.bean.BeanEndpoint
Used for configuring additional properties on the bean
setParameterTypes(Class<?>[]) - Method in class org.apache.camel.component.bean.MethodBean
 
setParams(List<RestOperationParamDefinition>) - Method in class org.apache.camel.model.rest.VerbDefinition
To specify the REST operation parameters using Swagger.
setParent(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ProcessorDefinition
 
setParentUnitOfWork(UnitOfWork) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
setParser(Object) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
To use a custom HL7 parser
setParserErrorHandler(Object) - Method in class org.apache.camel.model.dataformat.FhirDataformat
Registers an error handler which will be invoked when any parse errors are found
setParserFactoryRef(String) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
References to a custom parser factory to lookup in the registry
setParserOptions(Object) - Method in class org.apache.camel.model.dataformat.FhirDataformat
Sets the parser options object which will be used to supply default options to newly created parsers.
setPartClass(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Name of class used for fragment parsing.
setPartNamespace(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
XML namespace to use for fragment parsing.
setPassPhrase(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
A String used as passPhrase to encrypt/decrypt content.
setPassPhraseByte(byte[]) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
A byte[] used as passPhrase to encrypt/decrypt content.
setPassword(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the password to be used for basic authentication
setPassword(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The password to use for basic authentication.
setPassword(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the password for authentication when using client lookup
setPassword(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
The password
setPassword(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Password used when opening the private key (not used for encryption).
setPath(String) - Method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
setPath(String) - Method in class org.apache.camel.model.rest.RestDefinition
Path of the rest service, such as "/foo"
setPattern(ExchangePattern) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
setPattern(ExchangePattern) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the optional ExchangePattern used to invoke this endpoint
setPattern(String) - Method in class org.apache.camel.model.RemoveHeadersDefinition
Name or pattern of headers to remove.
setPattern(String) - Method in class org.apache.camel.model.RemovePropertiesDefinition
Name or pattern of properties to remove.
setPattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
Sets the new exchange pattern of the Exchange to be used from this point forward
setPattern(ExchangePattern) - Method in class org.apache.camel.model.ToDefinition
Sets the optional ExchangePattern used to invoke this endpoint
setPattern(ExchangePattern) - Method in class org.apache.camel.model.ToDynamicDefinition
 
setPattern(ExchangePattern) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setPermissions(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Adds permissions that controls which Java packages and classes XStream is allowed to use during unmarshal from xml/json to Java beans.
setPermissions(Class<?>...) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
To add permission for the given pojo classes.
setPermissions(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
Adds permissions that controls which Java packages and classes XStream is allowed to use during unmarshal from xml/json to Java beans.
setPermissions(Class<?>...) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
To add permission for the given pojo classes.
setPollingConsumerServicePool(ServicePool<PollingConsumer>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setPoolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the core pool size
setPoolSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
 
setPort(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
The port number to use for exposing the REST service.
setPortHeader(String) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
The header that holds the service port information, default ServiceCallConstants.SERVICE_PORT
setPortName(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Port Name to use for DNS/DNSSRV lookup.
setPortProtocol(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the Port Protocol to use for DNS/DNSSRV lookup.
setPredicate(Predicate) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setPreferTypes(Object) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set, when parsing resources the parser will try to use the given types when possible, in the order that they are provided (from highest to lowest priority).
setPreloadSize(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Sets how many messages should be preloaded (sent) before the route completes its initialization
setPreservePathElements(Boolean) - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
If the file name contains path elements, setting this option to true, allows the path to be maintained in the tar file.
setPreservePathElements(Boolean) - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
If the file name contains path elements, setting this option to true, allows the path to be maintained in the zip file.
setPrettyFlow(boolean) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Force the emitter to produce a pretty YAML document when using the flow style.
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
Sets the "pretty print" flag, meaning that the parser will encode resources with human-readable spacing and newlines between elements instead of condensing output as much as possible.
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
To enable pretty printing output nicely formatted.
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To enable pretty printing output nicely formatted.
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
To enable pretty printing output nicely formatted.
setProcessor(Processor) - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
Set processor to use
setProcessorFactory(ProcessorFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setProduceDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Allows a delay to be specified which causes a delay when a message is sent by the consumer (to simulate slow processing)
setProducerApiDoc(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
setProducerComponent(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Sets the name of the Camel component to use as the REST producer
setProducerServicePool(ServicePool<Producer>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setProduces(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
To define the content type what the REST service produces (uses for output), such as application/xml or application/json
setProduces(String) - Method in class org.apache.camel.model.rest.RestDefinition
To define the content type what the REST service produces (uses for output), such as application/xml or application/json This option will override what may be configured on a parent level
setProduces(String) - Method in class org.apache.camel.model.rest.VerbDefinition
To define the content type what the REST service produces (uses for output), such as application/xml or application/json This option will override what may be configured on a parent level
setPropagation(SagaPropagation) - Method in class org.apache.camel.model.SagaDefinition
Set the Saga propagation mode (REQUIRED, REQUIRES_NEW, MANDATORY, SUPPORTS, NOT_SUPPORTED, NEVER).
setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.cloud.ServiceCallExpressionConfiguration
Set client properties to use.
setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceChooserConfiguration
Set client properties to use.
setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceDiscoveryConfiguration
Set client properties to use.
setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceFilterConfiguration
Set client properties to use.
setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.cloud.ServiceCallServiceLoadBalancerConfiguration
Set client properties to use.
setPropertiesFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setProperty(DataFormat, CamelContext, String, Object) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
setProperty(CamelContext, Object, String, Object) - Method in class org.apache.camel.model.DataFormatDefinition
Sets a named property on the data format instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.language.ExpressionDefinition
Sets a named property on the object instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.LoadBalancerDefinition
Sets a named property on the data format instance using introspection
setProperty(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the exchange property
setProperty(String) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the exchange property
SetPropertyDefinition - Class in org.apache.camel.model
Sets a named property on the message exchange
SetPropertyDefinition() - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, String) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
setPropertyName(String) - Method in class org.apache.camel.model.RemovePropertyDefinition
Name of property to remove
setPropertyName(String) - Method in class org.apache.camel.model.SetPropertyDefinition
Name of exchange property to set a new value.
setPropertyPlaceholderLocations(String) - Method in class org.apache.camel.main.MainSupport
A list of locations to add for loading properties.
SetPropertyProcessor - Class in org.apache.camel.processor
A processor which sets the property on the exchange with an Expression
SetPropertyProcessor(Expression, Expression) - Constructor for class org.apache.camel.processor.SetPropertyProcessor
 
setPropertyRef(DataFormat, CamelContext, String, String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
 
setProto(String) - Method in class org.apache.camel.model.cloud.DnsServiceCallServiceDiscoveryConfiguration
The transport protocol of the desired service.
setProvider(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Java Cryptography Extension (JCE) provider, default is Bouncy Castle ("BC").
setQueueSizeRejectionThreshold(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Queue size rejection threshold is an artificial "max" size at which rejections will occur even if HystrixConfigurationCommon.maxQueueSize has not been reached.
setQuote(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the quote which by default is "
setQuote(String) - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
The quote symbol.
setQuoteAllFields(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
Whether or not all values must be quoted when writing them.
setQuoteDisabled(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Used to disable quotes
setQuoteEscape(String) - Method in class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
The quote escape symbol
setQuoteMode(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the quote mode
setRandomBackOff(Boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
setRandomBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setReadTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Read timeout for OkHttpClient
setRecipientKeyAlias(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The key alias to be used when retrieving the recipient's public or private key from a KeyStore when performing asymmetric key encryption or decryption.
setReconnectBaseSleepTime(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Initial amount of time to wait between retries.
setReconnectMaxRetries(Integer) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Max number of times to retry
setReconnectMaxSleepTime(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Max time in ms to sleep on each retry
setRecordConverterRef(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Refers to a custom CsvRecordConverter to lookup from the registry to use.
setRecordEndsOnNewline(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
Whether or not the record ends on new line.
setRecordSeparator(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets the record separator (aka new line) which by default is new line characters (CRLF)
setRecordSeparatorDisabled(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Used for disabling record separator
setRecursive(boolean) - Method in class org.apache.camel.impl.FileWatcherReloadStrategy
 
setRedeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the redelivery policy
setRedeliveryPolicyRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRedeliveryPolicyType(RedeliveryPolicyDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
Used for configuring redelivery options
setRef(String) - Method in class org.apache.camel.model.BeanDefinition
Sets a reference to a bean to use
setRef(String) - Method in class org.apache.camel.model.dataformat.CustomDataFormat
Reference to the custom DataFormat to lookup from the Camel registry.
setRef(String) - Method in class org.apache.camel.model.language.MethodCallExpression
Reference to bean to lookup in the registry
setRef(String) - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
Refers to the custom load balancer to lookup from the registry
setRef(String) - Method in class org.apache.camel.model.PolicyDefinition
 
setRef(String) - Method in class org.apache.camel.model.ProcessDefinition
Reference to the Processor to lookup in the registry to use.
setRef(String) - Method in class org.apache.camel.model.RestContextRefDefinition
Reference to the rest-dsl
setRef(String) - Method in class org.apache.camel.model.RouteBuilderDefinition
Reference to the route builder instance
setRef(String) - Method in class org.apache.camel.model.RouteContextRefDefinition
Reference to the routes in the xml dsl
setRef(String) - Method in class org.apache.camel.model.ThrowExceptionDefinition
Reference to the exception instance to lookup from the registry to throw
setRef(String) - Method in class org.apache.camel.model.TransactedDefinition
 
setRef(String) - Method in class org.apache.camel.model.transformer.CustomTransformerDefinition
Set a bean reference of the Transformer
setRef(String) - Method in class org.apache.camel.model.transformer.DataFormatTransformerDefinition
Set the reference of the DataFormat.
setRef(String) - Method in class org.apache.camel.model.transformer.EndpointTransformerDefinition
Set the reference of the Endpoint.
setRef(String) - Method in class org.apache.camel.model.validator.CustomValidatorDefinition
Set a bean reference of the Validator
setRef(String) - Method in class org.apache.camel.model.validator.EndpointValidatorDefinition
Set the reference of the Endpoint.
setRegex(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setRegex(boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
If the token is a regular expression pattern.
setRegistry(Registry) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the handler for tasks which cannot be executed by the thread pool.
setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadsDefinition
 
setRejectExecution(Boolean) - Method in class org.apache.camel.model.ThrottleDefinition
 
setRejectExecution(boolean) - Method in class org.apache.camel.processor.Throttler
 
setRejectOld(boolean) - Method in class org.apache.camel.model.config.StreamResequencerConfig
If true, throws an exception when messages older than the last delivered message are processed
setRejectOld(Boolean) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
setRejectOld(Boolean) - Method in class org.apache.camel.processor.StreamResequencer
 
setReloadStrategy(ReloadStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setReloadStrategy(ReloadStrategy) - Method in class org.apache.camel.main.MainSupport
Sets a custom ReloadStrategy to be used.
setRemoveOnDump(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setRemoveOnFailure(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setRemoveSpoolDirectoryWhenStopping(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setRemovingRoutes(boolean) - Method in class org.apache.camel.impl.RouteService
 
setReportCount(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
Sets the number of messages in a group on which we will report that messages have been received.
setReporter(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Allows a processor to added to the endpoint to report on progress of the test
setReportGroup(int) - Method in class org.apache.camel.component.mock.MockEndpoint
A number that is used to turn on throughput logging based on groups of the size.
setRepresenter(String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Representer to emit outgoing objects.
setRequest(Boolean) - Method in class org.apache.camel.model.dataformat.XmlRpcDataFormat
Whether to marshal/unmarshal request or response

Is by default false

setRequestLogEnabled(Boolean) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Whether HystrixCommand execution and events should be logged to HystrixRequestLog.
setRequired(Boolean) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter required flag.
setRequiredBody(Boolean) - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
setResequencerConfig(ResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
To configure the resequencer in using either batch or stream configuration.
setResolver(String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Resolver to detect implicit type
setResponseModel(String) - Method in class org.apache.camel.model.rest.RestOperationResponseMsgDefinition
 
setResponseMsgs(List<RestOperationResponseMsgDefinition>) - Method in class org.apache.camel.model.rest.VerbDefinition
Sets swagger operation response messages.
setRest(RestDefinition) - Method in class org.apache.camel.model.rest.VerbDefinition
 
setRestBindingDefinition(RestBindingDefinition) - Method in class org.apache.camel.model.RouteDefinition
 
setRestCollection(RestsDefinition) - Method in class org.apache.camel.builder.RouteBuilder
 
setRestConfiguration(RestConfiguration) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setRestDefinition(RestDefinition) - Method in class org.apache.camel.model.RouteDefinition
 
setRestRegistry(RestRegistry) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setRests(List<RestDefinition>) - Method in interface org.apache.camel.model.rest.RestContainer
Sets the RESTs to use
setRests(List<RestDefinition>) - Method in class org.apache.camel.model.rest.RestsDefinition
The rest services
setResultMinimumWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets the minimum expected amount of time (in millis) the MockEndpoint.assertIsSatisfied() will wait on a latch until it is satisfied
setResultQName(QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setResultType(Class<?>) - Method in class org.apache.camel.builder.SimpleBuilder
 
setResultType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setResultType(QName) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
setResultType(Class<?>) - Method in class org.apache.camel.model.language.JsonPathExpression
Sets the class of the result type (type from output)
setResultType(Class<?>) - Method in class org.apache.camel.model.language.SimpleExpression
Sets the class of the result type (type from output)
setResultType(Class<?>) - Method in class org.apache.camel.model.language.XPathExpression
Sets the class of the result type (type from output).
setResultType(Class<?>) - Method in class org.apache.camel.model.language.XQueryExpression
Sets the class of the result type (type from output).
setResultTypeName(String) - Method in class org.apache.camel.model.language.JsonPathExpression
Sets the class name of the result type (type from output)
setResultTypeName(String) - Method in class org.apache.camel.model.language.SimpleExpression
Sets the class name of the result type (type from output)
setResultTypeName(String) - Method in class org.apache.camel.model.language.XPathExpression
Sets the class name of the result type (type from output)

The default result type is NodeSet

setResultWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets the maximum amount of time (in millis) the MockEndpoint.assertIsSatisfied() will wait on a latch until it is satisfied
setRetainFirst(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies to only retain the first n'th number of received Exchanges.
setRetainLast(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies to only retain the last n'th number of received Exchanges.
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
setRetryAttemptedLogInterval(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRetryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the interval to log retry attempts
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
setRetryDelay(Long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
 
setRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setRetryWhile(Predicate) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setRetryWhile(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRetryWhilePolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRetryWhileRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setReverse(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
Whether to reverse the ordering.
setReverse(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setRoundRobin(Boolean) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
Whether or not the failover load balancer should operate in round robin mode or not.
setRoundRobin(Boolean) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
To enable round robin mode.
setRoundRobin(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setRoute(RouteDefinition) - Method in class org.apache.camel.model.rest.VerbDefinition
 
setRoute(Route) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
setRoute(Route) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
setRouteBuilderClasses(String) - Method in class org.apache.camel.main.MainSupport
 
setRouteBuilders(List<RouteBuilder>) - Method in class org.apache.camel.main.MainSupport
 
setRouteCollection(RoutesDefinition) - Method in class org.apache.camel.builder.RouteBuilder
 
setRouteController(RouteController) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setRouteController(RouteController) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setRouteId(String) - Method in class org.apache.camel.model.rest.VerbDefinition
The route id this rest-dsl is using (read-only)
setRoutePolicies(List<RoutePolicy>) - Method in class org.apache.camel.model.RouteDefinition
 
setRoutePolicyFactories(List<RoutePolicyFactory>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setRoutePolicyList(List<RoutePolicy>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setRoutePolicyRef(String) - Method in class org.apache.camel.model.RouteDefinition
Reference to custom RoutePolicy to use by the route.
setRouteProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.RouteDefinition
To set metadata as properties on the route.
setRoutes(List<RouteDefinition>) - Method in interface org.apache.camel.model.RouteContainer
Sets the routes to use
setRoutes(List<RouteDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setRoutesConfiguration(Map<String, ClusteredRouteConfiguration>) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
Sets the configurations for the routes.
setRouteScoped(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setSagaService(CamelSagaService) - Method in class org.apache.camel.model.SagaDefinition
 
setSamplePeriod(Long) - Method in class org.apache.camel.model.SamplingDefinition
Sets the sample period during which only a single Exchange will pass through.
setSaxon(Boolean) - Method in class org.apache.camel.model.language.XPathExpression
Whether to use Saxon.
setSchema(Object) - Method in class org.apache.camel.model.dataformat.AvroDataFormat
 
setSchema(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To validate against an existing schema.
setSchema(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
To validate against an existing schema.
setSchemaLocation(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To define the location of the schema
setSchemaSeverityLevel(Integer) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
Sets the schema severity level to use when validating against a schema.
setScheme(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
The scheme to use for exposing the REST service.
setScheme(String) - Method in class org.apache.camel.model.transformer.TransformerDefinition
Set a scheme name supported by the transformer.
setScopes(List<RestPropertyDefinition>) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
The available scopes for an OAuth2 security scheme
setScopes(String) - Method in class org.apache.camel.model.rest.SecurityDefinition
The scopes to allow (separate multiple scopes by comma)
setSecureTag(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The XPath reference to the XML Element selected for encryption/decryption.
setSecureTagContents(Boolean) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
A boolean value to specify whether the XML Element is to be encrypted or the contents of the XML Element false = Element Level true = Element Content Level
setSecurity(List<SecurityDefinition>) - Method in class org.apache.camel.model.rest.VerbDefinition
Sets the swagger security settings for this verb.
setSecurityDefinitions(RestSecuritiesDefinition) - Method in class org.apache.camel.model.rest.RestDefinition
Sets the security definitions such as Basic, OAuth2 etc.
setSecurityDefinitions(List<RestSecurityDefinition>) - Method in class org.apache.camel.model.rest.RestSecuritiesDefinition
Security definitions
setSequenceSender(SequenceSender<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets the sequence sender.
setServerBaseUrl(String) - Method in class org.apache.camel.model.dataformat.FhirDataformat
Sets the server's base URL used by this parser.
setServers(List<String>) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
Set the servers to blacklist.
setServers(String) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilter
Set the servers to blacklist.
setServers(List<String>) - Method in class org.apache.camel.impl.cloud.BlacklistServiceFilterFactory
 
setServers(List<String>) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
Set the servers.
setServers(String) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscovery
Set the servers.
setServers(List<String>) - Method in class org.apache.camel.impl.cloud.StaticServiceDiscoveryFactory
 
setServers(List<String>) - Method in class org.apache.camel.model.cloud.BlacklistServiceCallServiceFilterConfiguration
Sets the server blacklist.
setServers(List<String>) - Method in class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
Sets the server list.
setServiceCallConfiguration(ServiceCallConfigurationDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setServiceCallConfiguration(ServiceCallConfigurationDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the default service call configuration
setServiceCallConfigurations(List<ServiceCallConfigurationDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setServiceCallConfigurations(List<ServiceCallConfigurationDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the service call configurations
setServiceChooser(ServiceChooser) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
setServiceChooser(ServiceChooser) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceChooser to use.
setServiceChooser(ServiceChooser) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceChooser to use.
setServiceChooserRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceChooser to use.
setServiceChooserRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceChooser to use.
setServiceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
setServiceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
setServiceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceDiscovery to use.
setServiceDiscovery(ServiceDiscovery) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceDiscovery to use.
setServiceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the service-call configuration to use
setServiceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the ServiceDiscovery using the given configuration.
setServiceDiscoveryConfiguration(ServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the ServiceDiscovery using the given configuration.
setServiceDiscoveryConfigurations(List<ServiceCallServiceDiscoveryConfiguration>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
List of ServiceDiscovery configuration to use
setServiceDiscoveryList(List<ServiceDiscovery>) - Method in class org.apache.camel.impl.cloud.CombinedServiceDiscoveryFactory
 
setServiceDiscoveryRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceDiscovery to use.
setServiceDiscoveryRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceDiscovery to use.
setServiceFilter(ServiceFilter) - Method in class org.apache.camel.impl.cloud.DefaultServiceLoadBalancer
 
setServiceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
Set the ServiceFilter
setServiceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a custom ServiceFilter to use.
setServiceFilter(ServiceFilter) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a custom ServiceFilter to use.
setServiceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Configures the ServiceFilter using the given configuration.
setServiceFilterConfiguration(ServiceCallServiceFilterConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Configures the ServiceFilter using the given configuration.
setServiceFilterConfigurations(List<ServiceCallServiceFilterConfiguration>) - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceFilterConfiguration
List of ServiceFilter configuration to use
setServiceFilterList(List<ServiceFilter>) - Method in class org.apache.camel.impl.cloud.CombinedServiceFilterFactory
 
setServiceFilterRef(String) - Method in class org.apache.camel.model.cloud.CustomServiceCallServiceFilterConfiguration
Reference of a ServiceFilter
setServiceFilterRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets a reference to a custom ServiceFilter to use.
setServiceFilterRef(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets a reference to a custom ServiceFilter to use.
setServicePath(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The path to look for for service discovery
setSessionTimeout(String) - Method in class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
Session timeout.
setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.EnrichDefinition
 
setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.Enricher
 
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShorthandMethod(boolean) - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
Sets whether to support getter style method name, so you can say the method is called 'name' but it will invoke the 'getName' method.
setShorthandMethod(boolean) - Method in class org.apache.camel.component.bean.BeanProcessor
 
setShouldAppendHMAC(Boolean) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
Flag indicating that a Message Authentication Code should be calculated and appended to the encrypted data.
setShutdownAwaitTermination(long) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
setShutdownExecutorService(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShutdownNowOnTimeout(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setShutdownOptimisticLockingExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.model.RouteDefinition
To control how to shutdown the route.
setShutdownRoutesInReverseOrder(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.model.RouteDefinition
To control how to shutdown the route.
setShutdownStrategy(ShutdownStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setShutdownTimeoutCheckerExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setSignatureKeyFileName(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Filename of the keyring to use for signing (during encryption) or for signature verification (during decryption); must be accessible as a classpath resource (but you can specify a location in the file system by using the "file:" prefix).
setSignatureKeyRing(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Keyring used for signing/verifying as byte array.
setSignatureKeyUserid(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
User ID of the key in the PGP keyring used for signing (during encryption) or signature verification (during decryption).
setSignaturePassword(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Password used when opening the private key used for signing (during encryption).
setSignatureVerificationOption(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
Controls the behavior for verifying the signature during unmarshaling.
setSimpleFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setSize(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setSkipBindingOnErrorCode(Boolean) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Whether to skip binding on output if there is a custom HTTP error code header.
setSkipBindingOnErrorCode(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether to skip binding on output if there is a custom HTTP error code header.
setSkipBindingOnErrorCode(Boolean) - Method in class org.apache.camel.model.rest.RestDefinition
Whether to skip binding on output if there is a custom HTTP error code header.
setSkipBindingOnErrorCode(Boolean) - Method in class org.apache.camel.model.rest.VerbDefinition
Whether to skip binding on output if there is a custom HTTP error code header.
setSkipDuplicate(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setSkipEmptyLines(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
Whether or not the empty lines must be ignored.
setSkipFirst(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setSkipFirst(Boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
To skip the very first element
setSkipHeaderRecord(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether to skip the header record in the output
setSkipSendToOriginalEndpoint(Boolean) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
If set to true then the message is not sent to the original endpoint.
setSkipTrailingCharsUntilNewline(Boolean) - Method in class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
Whether or not the trailing characters until new line must be ignored.
setSleepForEmptyTest(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Allows a sleep to be specified to wait to check that this endpoint really is empty when MockEndpoint.expectedMessageCount(int) is called with zero
setSourceFile(File) - Method in class org.apache.camel.component.dataset.FileDataSet
 
setSourceFile(File, String) - Method in class org.apache.camel.component.dataset.FileDataSet
 
setSplit(boolean) - Method in class org.apache.camel.component.test.TestEndpoint
If enabled the messages loaded from the test endpoint will be split using new line delimiters so each line is an expected message.
setSpoolChiper(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSpoolDirectory(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSpoolDirectory(File) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSpoolThreshold(long) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSpoolUsedHeapMemoryThreshold(int) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
setSSLContextParameters(SSLContextParameters) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setSslContextParameters(SSLContextParameters) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
To configure security using SSLContextParameters.
setSslContextParameters(SSLContextParameters) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To configure security using SSLContextParameters.
setStartupOrder(Integer) - Method in class org.apache.camel.model.RouteDefinition
To configure the ordering of the routes being started
setState(String, String) - Method in class org.apache.camel.impl.FileStateRepository
 
setState(String, String) - Method in class org.apache.camel.impl.MemoryStateRepository
 
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Sets whether statistics is enabled.
setSticky(Boolean) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
Whether or not the failover load balancer should operate in sticky mode or not.
setSticky(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setStopOnAggregateException(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setStopOnAggregateException(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setStopOnAggregateException(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setStopOnAggregateException(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStopOnException(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setStopOnException(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setStopOnException(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setStopOnException(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
If this option is false then the aggregate method is not used for the very first aggregation.
setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.SplitDefinition
If this option is false then the aggregate method is not used if there was no data to enrich.
setStrategyMethodName(String) - Method in class org.apache.camel.model.AggregateDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
setStrategyMethodName(String) - Method in class org.apache.camel.model.MulticastDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
setStrategyMethodName(String) - Method in class org.apache.camel.model.RecipientListDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
setStrategyMethodName(String) - Method in class org.apache.camel.model.SplitDefinition
This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
setStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
A reference to lookup the AggregationStrategy in the Registry.
setStrategyRef(String) - Method in class org.apache.camel.model.MulticastDefinition
Refers to an AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast.
setStrategyRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
Sets a reference to the AggregationStrategy to be used to assemble the replies from the recipients, into a single outgoing message from the RecipientList.
setStrategyRef(String) - Method in class org.apache.camel.model.SplitDefinition
Sets a reference to the AggregationStrategy to be used to assemble the replies from the splitted messages, into a single outgoing message from the Splitter.
setStreamCache(String) - Method in class org.apache.camel.model.RouteDefinition
Whether stream caching is enabled on this route.
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setStreamCachingStrategy(StreamCachingStrategy) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setStreamConfig(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
 
setStreaming(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setStreaming(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
 
setStreaming(Boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setStreaming(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStreamName(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
The name of the stream to use.
setStripVersionsFromReferences(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (which is the default), resource references containing a version will have the version removed when the resource is encoded.
setSucceeded(int) - Method in class org.apache.camel.impl.ReloadStrategySupport
 
setSummaryMode(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (default is false) only elements marked by the FHIR specification as being "summary elements" will be included.
setSuppressExceptions(Boolean) - Method in class org.apache.camel.model.language.JsonPathExpression
Whether to suppress exceptions such as PathNotFoundException.
setSuppressLoggingOnTimeout(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setSuppressNarratives(Boolean) - Method in class org.apache.camel.model.dataformat.FhirDataformat
If set to true (default is false), narratives will not be included in the encoded values.
setTag(String) - Method in class org.apache.camel.model.rest.RestDefinition
To configure a special tag for the operations within this rest definition.
setTarget(Processor) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
setterBeanInjection(Method, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
setterInjection(Method, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
setterInjection(Method, Object, String, String, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
setterPropertyInjection(Method, String, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
 
setText(String) - Method in class org.apache.camel.model.DescriptionDefinition
The description as human readable text
setTextQualifier(String) - Method in class org.apache.camel.model.dataformat.FlatpackDataFormat
If the text is qualified with a character.
setThreadedAsyncMode(boolean) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setThreadName(String) - Method in class org.apache.camel.model.ThreadsDefinition
 
setThreadNamePattern(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
setThreadPoolFactory(ThreadPoolFactory) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
setThreadPoolKey(String) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Sets the thread pool key to use.
setThreadPoolRollingNumberStatisticalWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Number of buckets the rolling statistical window is broken into.
setThreadPoolRollingNumberStatisticalWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationCommon
Duration of statistical rolling window in milliseconds.
setThreadSafety(boolean) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setThreadSafety(Boolean) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
setThreadSafety(Boolean) - Method in class org.apache.camel.model.language.XPathExpression
Whether to enable thread-safety for the returned result of the xpath expression.
setTimeout(long) - Method in class org.apache.camel.component.test.TestEndpoint
The timeout to use when polling for message bodies from the URI
setTimeout(long) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
setTimeout(long, TimeUnit) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
setTimeout(Integer) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
setTimeout(long) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setTimeout(Integer) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the time the services will be retained.
setTimeout(Long) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To set the maximum time an action could take to complete.
setTimeout(long) - Method in class org.apache.camel.model.config.StreamResequencerConfig
Sets minimum time to wait for missing elements (messages).
setTimeout(Long) - Method in class org.apache.camel.model.MulticastDefinition
 
setTimeout(Long) - Method in class org.apache.camel.model.PollEnrichDefinition
 
setTimeout(Long) - Method in class org.apache.camel.model.RecipientListDefinition
 
setTimeout(Long) - Method in class org.apache.camel.model.SplitDefinition
 
setTimeout(long) - Method in class org.apache.camel.processor.PollEnricher
Sets the timeout to use when polling.
setTimeout(long) - Method in class org.apache.camel.processor.RecipientList
 
setTimeout(long) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets this sequencer's timeout value.
setTimeout(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
 
setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setTimeoutCheckerExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
 
setTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
Sets a timeout handler for receiving timeout notifications.
setTimeoutInMilliseconds(Long) - Method in class org.apache.camel.model.SagaDefinition
Set the maximum amount of time for the Saga.
setTimePeriodMillis(Long) - Method in class org.apache.camel.model.ThrottleDefinition
 
setTimePeriodMillis(long) - Method in class org.apache.camel.processor.Throttler
Sets the time period during which the maximum number of requests apply
setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
setTimeUnit(TimeUnit) - Method in class org.apache.camel.main.MainSupport
Sets the time unit duration (seconds by default).
setTimeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
Sets the time unit to use for keep alive time By default SECONDS is used.
setTimeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadsDefinition
 
setTimezone(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
If set then Jackson will use the Timezone when marshalling/unmarshalling.
setTo(ToDefinition) - Method in class org.apache.camel.model.rest.VerbDefinition
 
setToD(ToDynamicDefinition) - Method in class org.apache.camel.model.rest.VerbDefinition
 
setToEndpoint(Exchange, Processor) - Static method in class org.apache.camel.processor.MulticastProcessor
 
setToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setToken(String) - Method in class org.apache.camel.model.language.TokenizerExpression
The (start) token to use as tokenizer, for example you can use the new line token.
setTokenUrl(String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
The token URL to be used for this flow.
setToOrRoute(OptionalIdentifiedDefinition<?>) - Method in class org.apache.camel.model.rest.VerbDefinition
To route from this REST service to a Camel endpoint, or an inlined route
setToType(String) - Method in class org.apache.camel.model.transformer.TransformerDefinition
Set the 'to' data type name.
setToType(Class<?>) - Method in class org.apache.camel.model.transformer.TransformerDefinition
Set the 'to' data type using Java class.
setTrace(String) - Method in class org.apache.camel.model.RouteDefinition
Whether tracing is enabled on this route.
setTraceFilter(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setTracePattern(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setTracing(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setTracing(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setTrailingDelimiter(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets whether or not to add a trailing delimiter.
setTransformers(List<TransformerDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setTransformers(List<TransformerDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the transformers that can be referenced in the routes.
setTransformers(List<TransformerDefinition>) - Method in class org.apache.camel.model.transformer.TransformersDefinition
The configured transformers
setTrim(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Sets whether or not to trim leading and trailing blanks.
setTrim(Boolean) - Method in class org.apache.camel.model.language.ExpressionDefinition
Whether to trim the value to remove leading and trailing whitespaces and line breaks
setTrustCerts(Boolean) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets whether to turn on trust certificate check when using client lookup
setType(Class<?>) - Method in class org.apache.camel.component.bean.MethodBean
 
setType(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To set the discovery type, valid values are on-demand and watch.
setType(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
The java type to convert to
setType(BindyType) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
Whether to use csv, fixed or key value pairs mode.
setType(YAMLTypeFilterType) - Method in class org.apache.camel.model.dataformat.YAMLTypeFilterDefinition
Whether to filter by class type or regular expression
setType(String) - Method in class org.apache.camel.model.language.XQueryExpression
Sets the class name of the result type (type from output)

The default result type is NodeSet

setType(Class<? extends Policy>) - Method in class org.apache.camel.model.PolicyDefinition
Sets a policy type that this definition should scope within.
setType(String) - Method in class org.apache.camel.model.rest.RestBindingDefinition
Sets the class name to use for binding from input to POJO for the incoming data

The canonical name of the class of the input data.

setType(RestParamType) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
Sets the Swagger Parameter type.
setType(String) - Method in class org.apache.camel.model.rest.VerbDefinition
Sets the class name to use for binding from input to POJO for the incoming data This option will override what may be configured on a parent level.
setType(Class<? extends Policy>) - Method in class org.apache.camel.model.TransactedDefinition
Sets a policy type that this definition should scope within.
setType(String) - Method in class org.apache.camel.model.validator.ValidatorDefinition
Set the data type name.
setType(Class<?>) - Method in class org.apache.camel.model.validator.ValidatorDefinition
Set the data type using Java class.
setTypeClass(Class<?>) - Method in class org.apache.camel.model.ConvertBodyDefinition
 
setTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setTypeConverterRegistry(TypeConverterRegistry) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setTypeConverterStatisticsEnabled(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setTypeFilters(List<YAMLTypeFilterDefinition>) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Set the types SnakeYAML is allowed to un-marshall
setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setUnits(TimeUnit) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscoveryFactory
 
setUnits(TimeUnit) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the time unit for the timeout.
setUnits(String) - Method in class org.apache.camel.model.SamplingDefinition
Sets the time units for the sample period, defaulting to seconds.
setUnits(TimeUnit) - Method in class org.apache.camel.model.SamplingDefinition
Sets the time units for the sample period, defaulting to seconds.
setUnmarshallClass(Class<?>) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
Class use when unmarshalling from XML to Java.
setUnmarshallTypeName(String) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
Class name to use when unmarshalling from XML to Java.
setUnmarshalSingleObject(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
This options controls whether to unmarshal as a list of objects or as a single object only.
setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.BoonDataFormat
Class name of the java type to use when unarmshalling
setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Class of the java type to use when unarmshalling
setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Class of the java type to use when unarmshalling
setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Class of the object to be created
setUnmarshalTypeName(String) - Method in class org.apache.camel.model.dataformat.BoonDataFormat
Class name of the java type to use when unarmshalling
setUnmarshalTypeName(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Class name of the java type to use when unarmshalling
setUnmarshalTypeName(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Class name of the java type to use when unarmshalling
setUnmarshalTypeName(String) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Class name of the java type to use when unarmshalling
setUnwrapSingleInstance(Boolean) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
When unmarshalling should a single instance be unwrapped and returned instead of wrapped in a java.util.List.
setupManagement(Map<String, Object>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setupManagement(CamelContext, ManagementStrategy, LifecycleStrategy) - Method in class org.apache.camel.impl.DefaultManagementStrategyFactory
 
setupRoutes(boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setUri(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
The uri of the endpoint to send to.
setUri(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
The uri of the endpoint to send to.
setUri(String) - Method in class org.apache.camel.model.FromDefinition
Sets the URI of the endpoint to use
setUri(String) - Method in class org.apache.camel.model.InterceptFromDefinition
Intercept incoming messages from the uri or uri pattern.
setUri(String) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
Intercept sending to the uri or uri pattern.
setUri(String) - Method in class org.apache.camel.model.rest.VerbDefinition
Uri template of this REST service such as /{id}.
setUri(String) - Method in class org.apache.camel.model.SagaActionUriDefinition
 
setUri(String) - Method in class org.apache.camel.model.SendDefinition
Sets the uri of the endpoint to send to.
setUri(String) - Method in class org.apache.camel.model.ToDynamicDefinition
The uri of the endpoint to send to.
setUri(String) - Method in class org.apache.camel.model.transformer.EndpointTransformerDefinition
Set the URI of the Endpoint.
setUri(String) - Method in class org.apache.camel.model.validator.EndpointValidatorDefinition
Set the URI of the Endpoint.
setUri(String) - Method in class org.apache.camel.model.WireTapDefinition
The uri of the endpoint to wiretap to.
setUriDelimiter(String) - Method in class org.apache.camel.model.DynamicRouterDefinition
 
setUriDelimiter(String) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
setUris(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The URIs the client can connect to.
setUrl(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
 
setUrlSafe(Boolean) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
Instead of emitting '+' and '/' we emit '-' and '_' respectively.
setUrn(String) - Method in class org.apache.camel.model.InputTypeDefinition
Set input type URN.
setUrn(String) - Method in class org.apache.camel.model.OutputTypeDefinition
Set output type URN.
setUseApplicationContextClassLoader(boolean) - Method in class org.apache.camel.model.dataformat.YAMLDataFormat
Use ApplicationContextClassLoader as custom ClassLoader
setUseBreadcrumb(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setUseCollisionAvoidance(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
setUseDataType(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setUseDefaultObjectMapper(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
Whether to lookup and use default Jackson ObjectMapper from the registry.
setUsedForGeneratingNodeId(Boolean) - Method in class org.apache.camel.model.rest.VerbDefinition
 
setUseExponentialBackOff(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
setUseList(boolean) - Method in class org.apache.camel.model.dataformat.BoonDataFormat
To unarmshal to a List of Map or a List of Pojo.
setUseList(Boolean) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
To unarmshal to a List of Map or a List of Pojo.
setUseList(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
To unarmshal to a List of Map or a List of Pojo.
setUseMaps(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether the unmarshalling should produce maps (HashMap)for the lines values instead of lists.
setUseMDCLogging(Boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setUseOrderedMaps(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
Whether the unmarshalling should produce ordered maps (LinkedHashMap) for the lines values instead of lists.
setUseOriginalMessage(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setUseOriginalMessagePolicy(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
Will use the original input body when an Exchange for this on completion.
setUseOriginalMessagePolicy(Boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setUserName(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the username to be used for basic authentication
setUserName(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The user name to use for basic authentication.
setUsername(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the username for authentication when using client lookup
setUsername(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
The username
setUseSaxon(Boolean) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
setUseXForwardHeaders(Boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Whether to use X-Forward headers for Host and related setting.
setUsingIterator(Boolean) - Method in class org.apache.camel.model.dataformat.ASN1DataFormat
If the asn1 file has more then one entry, the setting this option to true, allows to work with the splitter EIP, to split the data using an iterator in a streaming mode.
setUsingIterator(Boolean) - Method in class org.apache.camel.model.dataformat.TarFileDataFormat
If the tar file has more then one entry, the setting this option to true, allows to work with the splitter EIP, to split the data using an iterator in a streaming mode.
setUsingIterator(Boolean) - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
If the zip file has more then one entry, the setting this option to true, allows to work with the splitter EIP, to split the data using an iterator in a streaming mode.
setUsingParallelCompression(Boolean) - Method in class org.apache.camel.model.dataformat.LZFDataFormat
Enable encoding (compress) using multiple processing cores.
setUuidGenerator(UuidGenerator) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setValidate(Boolean) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
Whether to validate the HL7 message

Is by default true.

setValidate(boolean) - Method in class org.apache.camel.model.InputTypeDefinition
Set if validation is required for this input type.
setValidate(boolean) - Method in class org.apache.camel.model.OutputTypeDefinition
Set if validation is required for this output type.
setValidating(Boolean) - Method in class org.apache.camel.model.dataformat.IcalDataFormat
Whether to validate.
setValidators(List<ValidatorDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
setValidators(List<ValidatorDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
Sets the validators that can be referenced in the routes.
setValidators(List<ValidatorDefinition>) - Method in class org.apache.camel.model.validator.ValidatorsDefinition
The configured transformers
setValue(String) - Method in class org.apache.camel.model.dataformat.YAMLTypeFilterDefinition
Value of type such as class name or regular expression
setValue(String) - Method in class org.apache.camel.model.GlobalOptionDefinition
Global option value
setValue(String) - Method in class org.apache.camel.model.PropertyDefinition
Property value
setValue(String) - Method in class org.apache.camel.model.rest.RestPropertyDefinition
Property value
setVerbs(List<VerbDefinition>) - Method in class org.apache.camel.model.rest.RestDefinition
The HTTP verbs this REST service accepts and uses
setVersion(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
SOAP version should either be 1.1 or 1.2.
setWhenClauses(List<WhenDefinition>) - Method in class org.apache.camel.model.ChoiceDefinition
Sets the when clauses
setWidth(Integer) - Method in class org.apache.camel.model.dataformat.BarcodeDataFormat
Width of the barcode
setWriteAsString(Boolean) - Method in class org.apache.camel.model.language.JsonPathExpression
Whether to write the output of each row/element as a JSON String value instead of a Map/POJO value.
setWriteTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Write timeout for OkHttpClient
setXml(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setXml(Boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
Whether the input is XML messages.
setXmlCipherAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
The cipher algorithm to be used for encryption/decryption of the XML message content.
setXmlDataFormat(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
Name of specific XML data format to use.
setXmlMapper(String) - Method in class org.apache.camel.model.dataformat.JacksonXMLDataFormat
Lookup and use the existing XmlMapper with the given id.
setXmlStreamWriterWrapper(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
To use a custom xml stream writer.
setXPathFactory(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setXpathFactory(XPathFactory) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
SharedCamelInternalProcessor - Class in org.apache.camel.processor
A Shared (thread safe) internal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWork Keeping track which route currently is being routed Execute RoutePolicy Gather JMX performance statics Tracing Debugging Message History Stream Caching Transformer ...
SharedCamelInternalProcessor(CamelInternalProcessorAdvice...) - Constructor for class org.apache.camel.processor.SharedCamelInternalProcessor
 
shareUnitOfWork() - Method in class org.apache.camel.model.EnrichDefinition
Shares the UnitOfWork with the parent and the resource exchange.
shareUnitOfWork() - Method in class org.apache.camel.model.MulticastDefinition
Shares the UnitOfWork with the parent and each of the sub messages.
shareUnitOfWork() - Method in class org.apache.camel.model.RecipientListDefinition
Shares the UnitOfWork with the parent and each of the sub messages.
shareUnitOfWork() - Method in class org.apache.camel.model.SplitDefinition
Shares the UnitOfWork with the parent and each of the sub messages.
ShareUnitOfWorkAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which are used when the option shareUnitOfWork is enabled on EIPs such as multicast, splitter or recipientList.
ShareUnitOfWorkAggregationStrategy(AggregationStrategy) - Constructor for class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
shouldFailOver(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Should the given failed Exchange failover?
shouldHandleException(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy whether the exchange has an exception that we should try to handle.
shouldRedeliver(Exchange, int, Predicate) - Method in class org.apache.camel.processor.RedeliveryPolicy
Returns true if the policy decides that the message exchange should be redelivered.
shouldRetry(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
shouldSpoolCache(long) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
shouldStartRoutes() - Method in class org.apache.camel.impl.AbstractCamelContext
Should we start newly added routes?
shouldTrace(ProcessorDefinition<?>, Exchange) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
Whether or not to trace the given processor definition.
showOptions() - Method in class org.apache.camel.main.MainSupport
Displays the command line options.
showOptionsHeader() - Method in class org.apache.camel.main.MainSupport
Displays the header message for the command line options.
shutdown() - Method in class org.apache.camel.impl.AbstractCamelContext
 
shutdown(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
shutdown() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
shutdown(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
shutdownGraceful(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
shutdownGraceful(ExecutorService, long) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
shutdownNow(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
 
shutdownNow(List<Consumer>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
Shutdown all the consumers immediately.
shutdownNow(Consumer) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
Shutdown the consumer immediately.
shutdownRoute(ShutdownRoute) - Method in class org.apache.camel.model.RouteDefinition
Configures a shutdown route option.
shutdownRouteService(RouteService) - Method in class org.apache.camel.impl.AbstractCamelContext
 
shutdownRoutesNow(List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
Shutdown all the consumers immediately.
shutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.model.RouteDefinition
Configures a shutdown running task option.
simple(String) - Static method in class org.apache.camel.builder.Builder
Returns a simple expression
simple(String, Class<?>) - Static method in class org.apache.camel.builder.Builder
Returns a simple expression
simple(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a simple expression value builder
simple(String, Class<?>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a simple expression value builder
simple(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Simple expression
simple(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Simple expression
simple(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Simple expression
simple(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a Simple expression
simple(String) - Static method in class org.apache.camel.builder.SimpleBuilder
 
simple(String, Class<?>) - Static method in class org.apache.camel.builder.SimpleBuilder
 
Simple - Annotation Type in org.apache.camel.language
Used to inject a simple expression into a field, property, method or parameter when using Bean Integration.
simple(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression.
simple(String, Class<?>) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression (or Predicate if the resultType is a Boolean, or boolean type).
SimpleBuilder - Class in org.apache.camel.builder
Creates an Simple language builder.
SimpleBuilder(String) - Constructor for class org.apache.camel.builder.SimpleBuilder
 
SimpleDataSet - Class in org.apache.camel.component.dataset
A simple DataSet that allows a static payload to be used to create each message exchange along with using a pluggable transformer to randomize the message.
SimpleDataSet() - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
 
SimpleDataSet(int) - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
 
simpleExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
SimpleExpression - Class in org.apache.camel.model.language
To use Camels built-in Simple language in Camel expressions or predicates.
SimpleExpression() - Constructor for class org.apache.camel.model.language.SimpleExpression
 
SimpleExpression(String) - Constructor for class org.apache.camel.model.language.SimpleExpression
 
SimpleExpression(Expression) - Constructor for class org.apache.camel.model.language.SimpleExpression
 
SimpleExpressionParser - Class in org.apache.camel.language.simple
A parser to parse simple language as a Camel Expression
SimpleExpressionParser(String, boolean, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.SimpleExpressionParser
 
simpleF(String, Object...) - Method in class org.apache.camel.builder.BuilderSupport
Returns a simple expression value builder, using String.format style
simpleF(String, Class<?>, Object...) - Method in class org.apache.camel.builder.BuilderSupport
Returns a simple expression value builder, using String.format style
simpleF(String, Object...) - Static method in class org.apache.camel.builder.SimpleBuilder
 
simpleF(String, Class<?>, Object...) - Static method in class org.apache.camel.builder.SimpleBuilder
 
SimpleFunctionEnd - Class in org.apache.camel.language.simple.ast
Ends a function
SimpleFunctionEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionEnd
 
SimpleFunctionExpression - Class in org.apache.camel.language.simple.ast
Represents one of built-in functions of the simple language
SimpleFunctionExpression(SimpleToken, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionExpression
 
SimpleFunctionStart - Class in org.apache.camel.language.simple.ast
Starts a function
SimpleFunctionStart(SimpleToken, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
SimpleIllegalSyntaxException - Exception in org.apache.camel.language.simple.types
Syntax error in the simple language expression.
SimpleIllegalSyntaxException(String, int, String) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
SimpleIllegalSyntaxException(String, int, String, Throwable) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
SimpleLanguage - Class in org.apache.camel.language.simple
A simple language which maps simple property style notations to access headers and bodies.
SimpleLanguage() - Constructor for class org.apache.camel.language.simple.SimpleLanguage
Default constructor.
SimpleNode - Interface in org.apache.camel.language.simple.ast
Represents a node in the Simple AST
SimpleParserException - Exception in org.apache.camel.language.simple.types
Holds information about error parsing the simple expression at a given location in the input.
SimpleParserException(String, int) - Constructor for exception org.apache.camel.language.simple.types.SimpleParserException
 
SimplePredicateParser - Class in org.apache.camel.language.simple
A parser to parse simple language as a Camel Predicate
SimplePredicateParser(String, boolean, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.SimplePredicateParser
 
SimpleToken - Class in org.apache.camel.language.simple.types
Holder for a token, with associated type and position in the input.
SimpleToken(SimpleTokenType, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
 
SimpleToken(SimpleTokenType, int, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
 
SimpleTokenizer - Class in org.apache.camel.language.simple
Tokenizer to create SimpleToken from the input.
SimpleTokenType - Class in org.apache.camel.language.simple.types
The different token types used by the simple parser.
SimpleTokenType(TokenType, String) - Constructor for class org.apache.camel.language.simple.types.SimpleTokenType
 
single() - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
singleCharOf(String, String) - Static method in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
singleQuotedLiteralText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
singleQuotedLiteralWithFunctionsText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
SingleQuoteEnd - Class in org.apache.camel.language.simple.ast
Ends a block enclosed by single quotes
SingleQuoteEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteEnd
 
SingleQuoteStart - Class in org.apache.camel.language.simple.ast
Starts a block enclosed by single quotes
SingleQuoteStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteStart
 
size() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
size() - Method in class org.apache.camel.impl.DefaultAsyncProcessorAwaitManager
 
size() - Method in class org.apache.camel.impl.DefaultConsumerCache
Returns the current size of the cache
size() - Method in class org.apache.camel.impl.DefaultEndpointUtilizationStatistics
 
size() - Method in class org.apache.camel.impl.DefaultInflightRepository
 
size(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
 
size() - Method in class org.apache.camel.impl.DefaultProducerCache
Returns the current size of the cache
size() - Method in class org.apache.camel.impl.DefaultRestRegistry
 
size() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
 
size() - Method in class org.apache.camel.impl.ServicePool
Returns the current size of the pool
size(int) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the in batch size for number of exchanges received
size() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the number of elements currently maintained by this resequencer.
skipBindingOnErrorCode(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify whether to skip binding output if there is a custom HTTP error code
skipBindingOnErrorCode(boolean) - Method in class org.apache.camel.model.rest.RestDefinition
 
skipDuplicate(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets whether to skip duplicates or not.
skipEmptyLines - Variable in class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
skipExpression(String, int) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an iterator to skip (iterate) the given expression
skipFirstExpression(Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression that skips the first element
skipIteratorExpression(Expression, int) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
skipSendToOriginalEndpoint() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
Skip sending the Exchange to the original intended endpoint
sleep() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
Method for sleeping during redelivery attempts.
sleep(long, int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Calculates the new redelivery delay based on the last one and then sleeps for the necessary amount of time.
sleep(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sleeps for the given delay
soapjaxb() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.1 JAXB data format
soapjaxb(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.1 JAXB data format
soapjaxb(String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.1 JAXB data format
soapjaxb(String, Object) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.1 JAXB data format
soapjaxb12() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.2 JAXB data format
soapjaxb12(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.2 JAXB data format
soapjaxb12(String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap 1.2 JAXB data format
soapjaxb12(String, Object) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Soap JAXB data format
SoapJaxbDataFormat - Class in org.apache.camel.model.dataformat
SOAP is a data format which uses JAXB2 and JAX-WS annotations to marshal and unmarshal SOAP payloads.
SoapJaxbDataFormat() - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
SoapJaxbDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
SoapJaxbDataFormat(String, String) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
SoapJaxbDataFormat(String, Object) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
 
sort(Comparator<?>) - Method in class org.apache.camel.builder.ValueBuilder
Sorts the current value using the given comparator.
sort(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the expression using a default sorting based on toString representation.
sort(Expression, Comparator<T>) - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the expression using the given comparator
sort() - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the expression
SortDefinition<T> - Class in org.apache.camel.model
Sorts the contents of the message
SortDefinition() - Constructor for class org.apache.camel.model.SortDefinition
 
SortDefinition(Expression) - Constructor for class org.apache.camel.model.SortDefinition
 
SortDefinition(Expression, Comparator<? super T>) - Constructor for class org.apache.camel.model.SortDefinition
 
sortExpression(Expression, Comparator) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a sort expression which will sort the expression with the given comparator.
SortProcessor<T> - Class in org.apache.camel.processor
A processor that sorts the expression using a comparator
SortProcessor(Expression, Comparator<? super T>) - Constructor for class org.apache.camel.processor.SortProcessor
 
spel(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a SpEL expression
spel(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an SpEL expression
SpEL - Annotation Type in org.apache.camel.language
An annotation for injection of Spring Expression Language (SpEL) expressions into method parameters, fields or properties.
SpELExpression - Class in org.apache.camel.model.language
To use Spring Expression Language (SpEL) in Camel expressions or predicates.
SpELExpression() - Constructor for class org.apache.camel.model.language.SpELExpression
 
SpELExpression(String) - Constructor for class org.apache.camel.model.language.SpELExpression
 
split() - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
split(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
split(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
SplitDefinition - Class in org.apache.camel.model
Splits a single message into many sub-messages.
SplitDefinition() - Constructor for class org.apache.camel.model.SplitDefinition
 
SplitDefinition(Expression) - Constructor for class org.apache.camel.model.SplitDefinition
 
SplitDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.SplitDefinition
 
Splitter - Class in org.apache.camel.processor
Implements a dynamic Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
Splitter(CamelContext, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
Splitter(CamelContext, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
sslContextParameters(SSLContextParameters) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
To configure security using SSLContextParameters.
sslContextParameters(SSLContextParameters) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To configure security using SSLContextParameters.
start() - Method in class org.apache.camel.impl.AbstractCamelContext
 
start() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
start() - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
start() - Method in class org.apache.camel.impl.DefaultDebugger
 
start() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
start() - Method in class org.apache.camel.impl.DefaultRoute
Do not invoke this method directly, use RouteController.startRoute(String) to start a route.
start() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
start() - Method in class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
start() - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
start() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
start() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
start() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
startAllRoutes() - Method in class org.apache.camel.impl.AbstractCamelContext
 
startAllRoutes() - Method in class org.apache.camel.impl.DefaultRouteController
 
startChildService(Route, List<Service>) - Method in class org.apache.camel.impl.RouteService
 
startRoute(RouteDefinition) - Method in class org.apache.camel.impl.AbstractCamelContext
 
startRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
startRoute(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
startRoute(String) - Method in class org.apache.camel.impl.DefaultRouteController
 
startRoute(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
startRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.AbstractCamelContext
 
startRouteService(RouteService, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
Starts the given route service
startService(Service, CamelContext, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Stats the given service
startSingleStepExchange(String, Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
 
startsWith(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
startsWith(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
startToken - Variable in class org.apache.camel.builder.TokenPairExpressionIterator
 
startupOrder(int) - Method in class org.apache.camel.model.ProcessorDefinition
 
startupOrder(int) - Method in class org.apache.camel.model.RouteDefinition
Configures the startup order for this route

Camel will reorder routes and star them ordered by 0..N where 0 is the lowest number and N the highest number.

State(Exchange, AsyncCallback, AsyncProcessor[]) - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer.State
 
State(Exchange, AsyncCallback, AsyncProcessor[]) - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
staticMap - Variable in class org.apache.camel.impl.AbstractDynamicRegistry
 
StaticServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
StaticServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
 
StaticServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration
 
StaticServiceDiscovery - Class in org.apache.camel.impl.cloud
A static list of known servers Camel Service Call EIP.
StaticServiceDiscovery() - Constructor for class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
StaticServiceDiscovery(List<ServiceDefinition>) - Constructor for class org.apache.camel.impl.cloud.StaticServiceDiscovery
 
staticServiceDiscovery() - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
 
staticServiceDiscovery() - Method in class org.apache.camel.model.cloud.CombinedServiceCallServiceDiscoveryConfiguration
 
staticServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
staticServiceDiscovery(StaticServiceCallServiceDiscoveryConfiguration) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
staticServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
StaticServiceDiscoveryFactory - Class in org.apache.camel.impl.cloud
 
StaticServiceDiscoveryFactory() - Constructor for class org.apache.camel.impl.cloud.StaticServiceDiscoveryFactory
 
staticSize() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
step() - Method in class org.apache.camel.model.ProcessorDefinition
Routes the message to a sequence of processors which is grouped together as one logical name.
step(String) - Method in class org.apache.camel.model.ProcessorDefinition
Routes the message to a sequence of processors which is grouped together as one logical name.
step() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
step - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
step(CamelSagaStep) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
stepBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
StepDefinition - Class in org.apache.camel.model
Routes the message to a sequence of processors which is grouped together as one logical name
StepDefinition() - Constructor for class org.apache.camel.model.StepDefinition
 
stepIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the current step id (if any)
StepProcessor - Class in org.apache.camel.processor
 
StepProcessor(CamelContext, Collection<Processor>, String) - Constructor for class org.apache.camel.processor.StepProcessor
 
sticky(Expression) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses sticky load balancer
StickyLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements a sticky load balancer using an Expression to calculate a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.
StickyLoadBalancer(Expression) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Sticky load balancer Sticky load balancing using an Expression to calculate a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.
StickyLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
stop() - Method in class org.apache.camel.impl.AbstractCamelContext
 
stop() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
stop() - Method in class org.apache.camel.impl.DefaultClaimCheckRepository
 
stop() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
stop() - Method in class org.apache.camel.impl.DefaultRoute
Do not invoke this method directly, use RouteController.stopRoute(String) to stop a route.
stop() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
stop() - Method in class org.apache.camel.impl.InterceptSendToEndpointProcessor
 
stop() - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
 
stop() - Method in class org.apache.camel.impl.MDCUnitOfWork
 
stop() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
stop() - Method in class org.apache.camel.model.ProcessorDefinition
Stops continue routing the current Exchange and marks it as completed.
stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Stops this resequencer (i.e.
stop() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
stopChildService(Route, Set<Service>, boolean) - Method in class org.apache.camel.impl.RouteService
 
StopDefinition - Class in org.apache.camel.model
Stops the processing of the current message
StopDefinition() - Constructor for class org.apache.camel.model.StopDefinition
 
stopOnAggregateException() - Method in class org.apache.camel.model.MulticastDefinition
If enabled, unwind exceptions occurring at aggregation time to the error handler when parallelProcessing is used.
stopOnAggregateException() - Method in class org.apache.camel.model.RecipientListDefinition
If enabled, unwind exceptions occurring at aggregation time to the error handler when parallelProcessing is used.
stopOnAggregateException() - Method in class org.apache.camel.model.SplitDefinition
If enabled, unwind exceptions occurring at aggregation time to the error handler when parallelProcessing is used.
stopOnException() - Method in class org.apache.camel.model.MulticastDefinition
Will now stop further processing if an exception or failure occurred during processing of an Exchange and the caused exception will be thrown.
stopOnException() - Method in class org.apache.camel.model.RecipientListDefinition
Will now stop further processing if an exception or failure occurred during processing of an Exchange and the caused exception will be thrown.
stopOnException() - Method in class org.apache.camel.model.SplitDefinition
Will now stop further processing if an exception or failure occurred during processing of an Exchange and the caused exception will be thrown.
StopProcessor - Class in org.apache.camel.processor
Stops continue processing the route and marks it as complete.
StopProcessor() - Constructor for class org.apache.camel.processor.StopProcessor
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
stopRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.AbstractCamelContext
 
stopRoute(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
stopRoute(String) - Method in class org.apache.camel.impl.DefaultRouteController
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultRouteController
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.DefaultRouteController
 
stopRoute(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.SupervisingRouteController
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.SupervisingRouteController
 
stopRouteService(RouteService, boolean) - Method in class org.apache.camel.impl.AbstractCamelContext
 
stopRouteService(RouteService) - Method in class org.apache.camel.impl.AbstractCamelContext
 
stopSingleStepExchange(String) - Method in class org.apache.camel.impl.DefaultDebugger
 
storeInBody() - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in the body of the IN message.
storeInHeader(String) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in an IN message header with the designated name.
storeInProperty(String) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in a property with the designated name.
storeNulls() - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Enables storing null values in the resulting collection.
strategy() - Method in class org.apache.camel.model.AggregateDefinition
Sets the AggregationStrategy to use with a fluent builder.
strategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate strategy to use
stream() - Method in class org.apache.camel.model.ResequenceDefinition
Configures the stream-based resequencing algorithm using the default configuration.
stream(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
Configures the stream-based resequencing algorithm using the given StreamResequencerConfig.
streamCaching() - Method in class org.apache.camel.model.RouteDefinition
Enable stream caching for this route.
streamCaching(String) - Method in class org.apache.camel.model.RouteDefinition
Enable stream caching for this route.
StreamCachingAdvice(StreamCachingStrategy) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
streaming() - Method in class org.apache.camel.model.MulticastDefinition
If enabled then Camel will process replies out-of-order, eg in the order they come back.
streaming() - Method in class org.apache.camel.model.RecipientListDefinition
If enabled then Camel will process replies out-of-order, eg in the order they come back.
streaming() - Method in class org.apache.camel.model.SplitDefinition
When in streaming mode, then the splitter splits the original message on-demand, and each splitted message is processed one by one.
StreamResequencer - Class in org.apache.camel.processor
A resequencer that re-orders a (continuous) stream of Exchanges.
StreamResequencer(CamelContext, Processor, SequenceElementComparator<Exchange>, Expression) - Constructor for class org.apache.camel.processor.StreamResequencer
Creates a new StreamResequencer instance.
StreamResequencerConfig - Class in org.apache.camel.model.config
Configures stream-processing resequence eip.
StreamResequencerConfig() - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using default values for capacity (1000) and timeout (1000L).
StreamResequencerConfig(int, long) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using the given values for capacity and timeout.
StreamResequencerConfig(int, long, ExpressionResultComparator) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using the given values for capacity and timeout.
StreamResequencerConfig(int, long, Boolean) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using the given values for capacity and timeout.
StreamResequencerConfig(int, long, Boolean, ExpressionResultComparator) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using the given values for capacity and timeout.
string() - Method in class org.apache.camel.builder.DataFormatClause
Uses the String data format
string(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the String data format supporting encoding using given charset
StringDataFormat - Class in org.apache.camel.impl
The text based data format supporting charset encoding.
StringDataFormat() - Constructor for class org.apache.camel.impl.StringDataFormat
 
StringDataFormat(String) - Constructor for class org.apache.camel.impl.StringDataFormat
 
StringDataFormat - Class in org.apache.camel.model.dataformat
String data format is a textual based format that supports character encoding.
StringDataFormat() - Constructor for class org.apache.camel.model.dataformat.StringDataFormat
 
stringResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to XPathConstants.STRING
subscribeMethod(Method, Object, String, String, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
SubscribeMethodProcessor - Class in org.apache.camel.impl
A Processor which is used for POJO @Consume where you can have multiple @Consume on the same endpoint/consumer and via predicate's can filter and call different methods.
SubscribeMethodProcessor(Endpoint) - Constructor for class org.apache.camel.impl.SubscribeMethodProcessor
 
SubUnitOfWorkProcessorAdvice() - Constructor for class org.apache.camel.processor.CamelInternalProcessor.SubUnitOfWorkProcessorAdvice
 
successor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
successor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate successor of the given element in this sequence or null if no successor exists.
successor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate successor of o2.
SUPERVISED - Static variable in class org.apache.camel.impl.SupervisingRouteController.FilterResult
 
supervised() - Method in class org.apache.camel.impl.SupervisingRouteController.FilterResult
 
SupervisingRouteController - Class in org.apache.camel.impl
A simple implementation of the RouteController that delays the startup of the routes after the camel context startup and retries to start failing routes.
SupervisingRouteController() - Constructor for class org.apache.camel.impl.SupervisingRouteController
 
SupervisingRouteController.Filter - Interface in org.apache.camel.impl
 
SupervisingRouteController.FilterResult - Class in org.apache.camel.impl
 
SupervisingRouteControllerFilters - Class in org.apache.camel.impl
 
SupervisingRouteControllerFilters.BlackList - Class in org.apache.camel.impl
 
supportedParameterTypes(BinaryOperatorType) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns the types of right hand side parameters this operator supports.
supportProcessor() - Method in interface org.apache.camel.component.bean.BeanHolder
Whether a Processor is supported by this bean holder.
supportProcessor() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
supportProcessor() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
supportProcessor() - Method in class org.apache.camel.component.bean.RegistryBean
 
supportsAutoWiring() - Method in class org.apache.camel.impl.DefaultInjector
 
SupportsSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the SUPPORTS propagation mode.
SupportsSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.SupportsSagaProcessor
 
supportsSuspension() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
supportTransacted() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
supportTransacted() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
supportTransacted() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Whether this error handler supports transacted exchanges.
supportTransacted() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
supportTransacted() - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
supportTransacted() - Method in class org.apache.camel.processor.ErrorHandlerSupport
Whether this error handler supports transacted exchanges or not.
supportTransacted() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
suspend() - Method in class org.apache.camel.impl.AbstractCamelContext
 
suspend() - Method in class org.apache.camel.impl.BreakpointSupport
 
suspend(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
 
suspendAllBreakpoints() - Method in class org.apache.camel.impl.DefaultDebugger
 
suspendNow(Consumer) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
Suspends/stops the consumer immediately.
suspendRoute(String) - Method in class org.apache.camel.impl.AbstractCamelContext
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.AbstractCamelContext
 
suspendRoute(String) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.cluster.ClusteredRouteController
 
suspendRoute(String) - Method in class org.apache.camel.impl.DefaultRouteController
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultRouteController
 
suspendRoute(String) - Method in class org.apache.camel.impl.SupervisingRouteController
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.SupervisingRouteController
 
suspendRouteService(RouteService) - Method in class org.apache.camel.impl.AbstractCamelContext
 
syncDelayed() - Method in class org.apache.camel.model.DelayDefinition
Enables asynchronous delay which means the thread will not block while delaying.
syslog() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Syslog data format
SyslogDataFormat - Class in org.apache.camel.model.dataformat
The Syslog dataformat is used for working with RFC3164 and RFC5424 messages (logging and monitoring).
SyslogDataFormat() - Constructor for class org.apache.camel.model.dataformat.SyslogDataFormat
 
SYSTEM_PROPERTIES_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
systemEnvironmentExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system environment value with the given name
systemEnvironmentExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system environment value with the given name
systemProperty(String) - Static method in class org.apache.camel.builder.Builder
Returns an expression for the given system property
systemProperty(String, String) - Static method in class org.apache.camel.builder.Builder
Returns an expression for the given system property
systemProperty(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given system property
systemProperty(String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given system property
systemPropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system property value with the given name
systemPropertyExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system property value with the given name

T

tag(String) - Method in class org.apache.camel.model.rest.RestDefinition
To set the tag to use of this REST service
tagToken - Variable in class org.apache.camel.builder.TokenXMLExpressionIterator
 
tarFile() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Tar file data format
TarFileDataFormat - Class in org.apache.camel.model.dataformat
The Tar File data format is a message compression and de-compression format of tar files.
TarFileDataFormat() - Constructor for class org.apache.camel.model.dataformat.TarFileDataFormat
 
task() - Method in interface org.apache.camel.builder.AdviceWithTask
The task to execute
templateText() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
test(CamelContext, String, RouteDefinition) - Method in interface org.apache.camel.impl.cluster.ClusteredRouteFilter
Test if the route should be clustered or not.
test(CamelContext, String, RouteDefinition) - Method in class org.apache.camel.impl.cluster.ClusteredRouteFilters.BlackList
 
test(CamelContext, String, RouteDefinition) - Method in class org.apache.camel.impl.cluster.ClusteredRouteFilters.IsAutoStartup
 
TestComponent - Class in org.apache.camel.component.test
The Test Component is for simplifying unit and integration tests.
TestComponent() - Constructor for class org.apache.camel.component.test.TestComponent
 
TestEndpoint - Class in org.apache.camel.component.test
The test component extends the mock component by on startup to pull messages from another endpoint to set the expected message bodies.
TestEndpoint(String, Component) - Constructor for class org.apache.camel.component.test.TestEndpoint
 
text - Variable in class org.apache.camel.language.simple.ast.LiteralExpression
 
threadName(String) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the thread name to use.
threadNameExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the current thread name
ThreadPoolBuilder - Class in org.apache.camel.builder
A builder to create thread pools.
ThreadPoolBuilder(CamelContext) - Constructor for class org.apache.camel.builder.ThreadPoolBuilder
 
threadPoolKey(String) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Sets the thread pool key to use.
threadPoolKey(String) - Method in class org.apache.camel.model.HystrixDefinition
Sets the thread pool key to use.
ThreadPoolProfileBuilder - Class in org.apache.camel.builder
Builder to build ThreadPoolProfile.
ThreadPoolProfileBuilder(String) - Constructor for class org.apache.camel.builder.ThreadPoolProfileBuilder
 
ThreadPoolProfileBuilder(String, ThreadPoolProfile) - Constructor for class org.apache.camel.builder.ThreadPoolProfileBuilder
 
ThreadPoolProfileDefinition - Class in org.apache.camel.model
To configure thread pools
ThreadPoolProfileDefinition() - Constructor for class org.apache.camel.model.ThreadPoolProfileDefinition
 
threadPoolRollingNumberStatisticalWindowBuckets(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Number of buckets the rolling statistical window is broken into.
threadPoolRollingNumberStatisticalWindowInMilliseconds(Integer) - Method in class org.apache.camel.model.HystrixConfigurationDefinition
Duration of statistical rolling window in milliseconds.
threads() - Method in class org.apache.camel.model.ProcessorDefinition
Continues processing the Exchange using asynchronous routing engine.
threads(int) - Method in class org.apache.camel.model.ProcessorDefinition
Continues processing the Exchange using asynchronous routing engine.
threads(int, int) - Method in class org.apache.camel.model.ProcessorDefinition
Continues processing the Exchange using asynchronous routing engine.
threads(int, int, String) - Method in class org.apache.camel.model.ProcessorDefinition
Continues processing the Exchange using asynchronous routing engine.
threadSafety(boolean) - Method in class org.apache.camel.builder.xml.XPathBuilder
Whether to enable thread-safety for the returned result of the xpath expression.
ThreadsDefinition - Class in org.apache.camel.model
Specifies that all steps after this node are processed asynchronously
ThreadsDefinition() - Constructor for class org.apache.camel.model.ThreadsDefinition
 
ThreadsProcessor - Class in org.apache.camel.processor
Threads processor that leverage a thread pool for continue processing the Exchanges using the asynchronous routing engine.
ThreadsProcessor(CamelContext, ExecutorService, boolean, ThreadPoolRejectedPolicy) - Constructor for class org.apache.camel.processor.ThreadsProcessor
 
thrift() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Thrift data format
thrift(Object) - Method in class org.apache.camel.builder.DataFormatClause
 
thrift(Object, String) - Method in class org.apache.camel.builder.DataFormatClause
 
thrift(String) - Method in class org.apache.camel.builder.DataFormatClause
 
thrift(String, String) - Method in class org.apache.camel.builder.DataFormatClause
 
ThriftDataFormat - Class in org.apache.camel.model.dataformat
The Thrift data format is used for serialization and deserialization of messages using Apache Thrift binary dataformat.
ThriftDataFormat() - Constructor for class org.apache.camel.model.dataformat.ThriftDataFormat
 
ThriftDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.ThriftDataFormat
 
ThriftDataFormat(String, String) - Constructor for class org.apache.camel.model.dataformat.ThriftDataFormat
 
throttle() - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler using a fluent builder.
throttle(long) - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded, or that we don't exceed an agreed SLA with some external service.
throttle(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded, or that we don't exceed an agreed SLA with some external service.
throttle(Expression, long) - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded, or that we don't exceed an agreed SLA with some external service.
throttle(Expression, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded, or that we don't exceed an agreed SLA with some external service.
ThrottleDefinition - Class in org.apache.camel.model
Controls the rate at which messages are passed to the next node in the route
ThrottleDefinition() - Constructor for class org.apache.camel.model.ThrottleDefinition
 
ThrottleDefinition(Expression) - Constructor for class org.apache.camel.model.ThrottleDefinition
 
ThrottleDefinition(Expression, Expression) - Constructor for class org.apache.camel.model.ThrottleDefinition
 
Throttler - Class in org.apache.camel.processor
A Throttler will set a limit on the maximum number of message exchanges which can be sent to a processor within a specific time period.
Throttler(CamelContext, Expression, long, ScheduledExecutorService, boolean, boolean, Expression) - Constructor for class org.apache.camel.processor.Throttler
 
ThrottlerRejectedExecutionException - Exception in org.apache.camel.processor
 
ThrottlerRejectedExecutionException(String) - Constructor for exception org.apache.camel.processor.ThrottlerRejectedExecutionException
 
throwException(Exception) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the exception on the Exchange
throwException(Class<? extends Exception>, String) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the exception on the Exchange
ThrowExceptionDefinition - Class in org.apache.camel.model
Throws an exception
ThrowExceptionDefinition() - Constructor for class org.apache.camel.model.ThrowExceptionDefinition
 
ThrowExceptionProcessor - Class in org.apache.camel.processor
The processor which sets an Exception on the Exchange
ThrowExceptionProcessor(Exception) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
 
ThrowExceptionProcessor(Exception, Class<? extends Exception>, String) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
 
tidyMarkup(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Return WellFormed HTML (an XML Document) either String or Node
tidyMarkup() - Method in class org.apache.camel.builder.DataFormatClause
Return TidyMarkup in the default format as Node
TidyMarkupDataFormat - Class in org.apache.camel.model.dataformat
TidyMarkup data format is used for parsing HTML and return it as pretty well-formed HTML.
TidyMarkupDataFormat() - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
TidyMarkupDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
Time - Class in org.apache.camel.component.mock
A helper class for working with times in various units
Time(long, TimeUnit) - Constructor for class org.apache.camel.component.mock.Time
 
TimeClassUnit(TimeClause, int) - Constructor for class org.apache.camel.component.mock.TimeClause.TimeClassUnit
 
TimeClassUnit(TimeClause, int, int) - Constructor for class org.apache.camel.component.mock.TimeClause.TimeClassUnit
 
TimeClause - Class in org.apache.camel.component.mock
Represents time based clauses for setting expectations on the mocks.
TimeClause(Expression, Expression) - Constructor for class org.apache.camel.component.mock.TimeClause
 
TimeClause.TimeClassUnit - Class in org.apache.camel.component.mock
 
timeout(Exchange, int, int, long) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
 
timeout(Exchange, int, int, long) - Method in interface org.apache.camel.builder.FlexibleAggregationStrategy.TimeoutAwareMixin
 
timeout(long) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
timeout(long, TimeUnit) - Method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
timeout(Integer) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the time the services will be retained.
timeout(Long) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To set the maximum time an action could take to complete.
timeout(long) - Method in class org.apache.camel.model.MulticastDefinition
Sets a total timeout specified in millis, when using parallel processing.
timeout(long) - Method in class org.apache.camel.model.PollEnrichDefinition
Timeout in millis when polling from the external service.
timeout(long) - Method in class org.apache.camel.model.RecipientListDefinition
Sets a total timeout specified in millis, when using parallel processing.
timeout(long) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the timeout
timeout(long, TimeUnit) - Method in class org.apache.camel.model.SagaDefinition
 
timeout(long) - Method in class org.apache.camel.model.SplitDefinition
Sets a total timeout specified in millis, when using parallel processing.
timeout(Exchange, int, int, long) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
timeout() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
Timeout - Class in org.apache.camel.processor.resequencer
A timer task that notifies handlers about scheduled timeouts.
Timeout(Timer, long) - Constructor for class org.apache.camel.processor.resequencer.Timeout
Creates a new timeout task using the given Timer instance and timeout value.
timeout(Timeout) - Method in interface org.apache.camel.processor.resequencer.TimeoutHandler
Handles a timeout notification.
timeoutAware(FlexibleAggregationStrategy.TimeoutAwareMixin) - Method in class org.apache.camel.builder.FlexibleAggregationStrategy
Plugs in logic to execute when a timeout occurs.
timeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
If using either of the completionTimeout, completionTimeoutExpression, or completionInterval options a background thread is created to check for the completion for every aggregator.
timeoutCheckerExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
If using either of the completionTimeout, completionTimeoutExpression, or completionInterval options a background thread is created to check for the completion for every aggregator.
TimeoutHandler - Interface in org.apache.camel.processor.resequencer
Implemented by classes that handle timeout notifications.
timePeriodMillis(long) - Method in class org.apache.camel.model.ThrottleDefinition
Sets the time period during which the maximum request count is valid for
timeUnit - Variable in class org.apache.camel.main.MainSupport
 
timeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
 
timeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadsDefinition
Sets the keep alive time unit.
TimeUnitAdapter - Class in org.apache.camel.model
TimeUnitAdapter is a simple adapter to convert between Strings and instances of the TimeUnit enumeration
TimeUnitAdapter() - Constructor for class org.apache.camel.model.TimeUnitAdapter
 
timeUnits(TimeUnit) - Method in class org.apache.camel.model.SamplingDefinition
Sets the time units for the sample period, defaulting to seconds.
to(String) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
to(Endpoint) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
to(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given endpoint
to(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given endpoint
to(ExchangePattern, String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange with certain exchange pattern to the given endpoint

Notice the existing MEP is preserved

to(ExchangePattern, Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange with certain exchange pattern to the given endpoint

Notice the existing MEP is preserved

to(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(ExchangePattern, String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints

Notice the existing MEP is preserved

to(ExchangePattern, Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints

Notice the existing MEP is preserved

to(ExchangePattern, Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(String) - Method in class org.apache.camel.model.rest.RestDefinition
Routes directly to the given static endpoint.
toD(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given dynamic endpoint
toD(String, int) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given dynamic endpoint
toD(String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given dynamic endpoint
toD(String) - Method in class org.apache.camel.model.rest.RestDefinition
Routes directly to the given dynamic endpoint.
ToDefinition - Class in org.apache.camel.model
Sends the message to a static endpoint
ToDefinition() - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(String) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(Endpoint) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(String, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDynamicDefinition - Class in org.apache.camel.model
Sends the message to a dynamic endpoint

You can specify multiple languages in the uri separated by the plus sign, such as mock:+language:xpath:/order/@uri where mock: would be a prefix to a xpath expression.

ToDynamicDefinition() - Constructor for class org.apache.camel.model.ToDynamicDefinition
 
ToDynamicDefinition(String) - Constructor for class org.apache.camel.model.ToDynamicDefinition
 
toExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Deprecated.
not in use, and not available in XML DSL
toExpressionDefinition(Expression) - Static method in class org.apache.camel.model.ExpressionNodeHelper
Determines which ExpressionDefinition describes the given expression best possible.
toExpressionDefinition(Predicate) - Static method in class org.apache.camel.model.ExpressionNodeHelper
Determines which ExpressionDefinition describes the given predicate best possible.
toF(String, Object...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given endpoint
token - Variable in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
token - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
tokenize(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean, int, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, boolean, String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, int) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, int, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the message body
tokenize(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the given header
tokenize(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token expression on the given header
tokenize(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the message body
tokenize(String, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the message body
tokenize(String, int, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the message body
tokenize(String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the message body
tokenize(String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the message body
tokenize(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize(String, String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize(String, String, boolean, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize(String, String, boolean, int, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize(String, String, boolean, String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token expression on the given header
tokenize() - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(String, int, boolean) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(String, String, boolean) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String) - Static method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
tokenize(String, char) - Static method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
tokenize(String, String) - Static method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
tokenize(String, String, char) - Static method in class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
tokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given token
TokenizeLanguage - Class in org.apache.camel.language.tokenizer
A language for tokenizer expressions.
TokenizeLanguage() - Constructor for class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizePair(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token pair expression on the message body.
tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token pair expression on the message body
tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token pair expression on the message body
tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenizePair(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizePairExpression(String, String, boolean) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an TokenPairExpressionIterator expression
TokenizerExpression - Class in org.apache.camel.model.language
To use Camel message body or header with a tokenizer in Camel expressions or predicates.
TokenizerExpression() - Constructor for class org.apache.camel.model.language.TokenizerExpression
 
tokenizeXML(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a XML token expression on the message body with XML content
tokenizeXML(String, int) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a XML token expression on the message body with XML content
tokenizeXML(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token pair expression on the message body with XML content
tokenizeXML(String, String, int) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a token pair expression on the message body with XML content
tokenizeXML(String, String) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenizeXML(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizeXMLAwareExpression(String, char) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
tokenizeXMLAwareExpression(String, char, int) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
tokenizeXMLExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an TokenXMLExpressionIterator expression
tokenizeXMLPair(String, String, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token pair expression on the message body with XML content
tokenizeXMLPair(String, String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates a token pair expression on the message body with XML content
TokenPairExpressionIterator - Class in org.apache.camel.builder
Expression to walk a Message body using an Iterator, which grabs the content between a start and end token.
TokenPairExpressionIterator(String, String, boolean) - Constructor for class org.apache.camel.builder.TokenPairExpressionIterator
 
tokens - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
TokenType - Enum in org.apache.camel.language.simple.types
Classifications of known token types.
TokenXMLExpressionIterator - Class in org.apache.camel.builder
Expression to walk a Message XML body using an Iterator, which grabs the content between a XML start and end token, where the end token corresponds implicitly to either the end tag or the self-closing start tag.
TokenXMLExpressionIterator(String, String) - Constructor for class org.apache.camel.builder.TokenXMLExpressionIterator
 
toMillis() - Method in class org.apache.camel.component.mock.Time
 
topic() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses topic load balancer
TopicLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A LoadBalancer implementations which sends to all destinations (rather like JMS Topics).
TopicLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
TopicLoadBalancer.State - Class in org.apache.camel.processor.loadbalancer
 
TopicLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Topic load balancer The topic load balancer sends to all destinations (rather like JMS Topics)
TopicLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
 
toPredicate(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
Converts the given expression into an Predicate
toString() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
toString() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
toString() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
toString() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
toString() - Method in class org.apache.camel.builder.NotifyBuilder
 
toString() - Method in class org.apache.camel.builder.RouteBuilder
 
toString() - Method in class org.apache.camel.builder.SimpleBuilder
 
toString() - Method in class org.apache.camel.builder.TokenPairExpressionIterator
 
toString() - Method in class org.apache.camel.builder.ValueBuilder
 
toString() - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
toString() implementation that outputs the namespace mappings with the following format: "[me: {prefix -> value}, {prefix -> value}], [parent: {prefix -> value}, {prefix -> value}].
toString() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
toString() - Method in class org.apache.camel.component.bean.AbstractBeanProcessor
 
toString() - Method in class org.apache.camel.component.bean.BeanInvocation
 
toString() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
toString() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
 
toString() - Method in class org.apache.camel.component.bean.MethodInfo
 
toString() - Method in class org.apache.camel.component.bean.ParameterInfo
 
toString() - Method in class org.apache.camel.component.bean.RegistryBean
 
toString() - Method in class org.apache.camel.component.mock.Time
 
toString() - Method in class org.apache.camel.component.mock.TimeClause
 
toString() - Method in class org.apache.camel.impl.AbstractCamelContext
 
toString() - Method in class org.apache.camel.impl.AbstractDynamicRegistry
 
toString() - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition
 
toString() - Method in class org.apache.camel.impl.cloud.RandomServiceChooser
 
toString() - Method in class org.apache.camel.impl.cloud.RoundRobinServiceChooser
 
toString() - Method in class org.apache.camel.impl.DefaultConsumerCache
 
toString() - Method in class org.apache.camel.impl.DefaultDebugger
 
toString() - Method in class org.apache.camel.impl.DefaultEndpointRegistry
 
toString() - Method in class org.apache.camel.impl.DefaultInterceptSendToEndpoint
 
toString() - Method in class org.apache.camel.impl.DefaultProducerCache
 
toString() - Method in class org.apache.camel.impl.DefaultRoute
 
toString() - Method in class org.apache.camel.impl.DefaultRouteError
 
toString() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
 
toString() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
 
toString() - Method in class org.apache.camel.impl.DefaultTransformerRegistry
 
toString() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
toString() - Method in class org.apache.camel.impl.DefaultValidatorRegistry
 
toString() - Method in class org.apache.camel.impl.DeferProducer
 
toString() - Method in class org.apache.camel.impl.EndpointKey
 
toString() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
toString() - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
 
toString() - Method in class org.apache.camel.impl.MDCUnitOfWork
 
toString() - Method in class org.apache.camel.impl.SubscribeMethodProcessor
 
toString() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
toString() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
toString() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
toString() - Method in class org.apache.camel.language.bean.BeanExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
toString() - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
toString() - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
toString() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
toString() - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
toString() - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
toString() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
toString() - Method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
toString() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
toString() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
 
toString() - Method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
toString() - Method in class org.apache.camel.main.MainDurationEventNotifier
 
toString() - Method in class org.apache.camel.model.AggregateDefinition
 
toString() - Method in class org.apache.camel.model.BeanDefinition
 
toString() - Method in class org.apache.camel.model.CatchDefinition
 
toString() - Method in class org.apache.camel.model.ChoiceDefinition
 
toString() - Method in class org.apache.camel.model.ClaimCheckDefinition
 
toString() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
toString() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
toString() - Method in class org.apache.camel.model.dataformat.CustomDataFormat
 
toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
 
toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
 
toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
 
toString() - Method in class org.apache.camel.model.DelayDefinition
 
toString() - Method in class org.apache.camel.model.DynamicRouterDefinition
 
toString() - Method in class org.apache.camel.model.EnrichDefinition
 
toString() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
toString() - Method in class org.apache.camel.model.FilterDefinition
 
toString() - Method in class org.apache.camel.model.FinallyDefinition
 
toString() - Method in class org.apache.camel.model.FromDefinition
 
toString() - Method in class org.apache.camel.model.HystrixDefinition
 
toString() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
toString() - Method in class org.apache.camel.model.InOnlyDefinition
 
toString() - Method in class org.apache.camel.model.InOutDefinition
 
toString() - Method in class org.apache.camel.model.InputTypeDefinition
 
toString() - Method in class org.apache.camel.model.InterceptDefinition
 
toString() - Method in class org.apache.camel.model.InterceptFromDefinition
 
toString() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
toString() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
toString() - Method in class org.apache.camel.model.language.MethodCallExpression
 
toString() - Method in class org.apache.camel.model.language.TokenizerExpression
 
toString() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.LoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.LogDefinition
 
toString() - Method in class org.apache.camel.model.LoopDefinition
 
toString() - Method in class org.apache.camel.model.MarshalDefinition
 
toString() - Method in class org.apache.camel.model.MulticastDefinition
 
toString() - Method in class org.apache.camel.model.OnCompletionDefinition
 
toString() - Method in class org.apache.camel.model.OnExceptionDefinition
 
toString() - Method in class org.apache.camel.model.OnFallbackDefinition
 
toString() - Method in class org.apache.camel.model.OtherwiseDefinition
 
toString() - Method in class org.apache.camel.model.OutputDefinition
 
toString() - Method in class org.apache.camel.model.OutputTypeDefinition
 
toString() - Method in class org.apache.camel.model.PolicyDefinition
 
toString() - Method in class org.apache.camel.model.PollEnrichDefinition
 
toString() - Method in class org.apache.camel.model.ProcessDefinition
 
toString() - Method in class org.apache.camel.model.RecipientListDefinition
 
toString() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
toString() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
toString() - Method in class org.apache.camel.model.RemoveHeadersDefinition
 
toString() - Method in class org.apache.camel.model.RemovePropertiesDefinition
 
toString() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
toString() - Method in class org.apache.camel.model.ResequenceDefinition
 
toString() - Method in class org.apache.camel.model.rest.RestBindingDefinition
 
toString() - Method in class org.apache.camel.model.rest.RestsDefinition
 
toString() - Method in class org.apache.camel.model.RestContextRefDefinition
 
toString() - Method in class org.apache.camel.model.RollbackDefinition
 
toString() - Method in class org.apache.camel.model.RouteBuilderDefinition
 
toString() - Method in class org.apache.camel.model.RouteContextRefDefinition
 
toString() - Method in class org.apache.camel.model.RouteDefinition
 
toString() - Method in class org.apache.camel.model.RoutesDefinition
 
toString() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
toString() - Method in class org.apache.camel.model.SagaActionUriDefinition
 
toString() - Method in class org.apache.camel.model.SagaDefinition
 
toString() - Method in class org.apache.camel.model.SagaOptionDefinition
 
toString() - Method in class org.apache.camel.model.SamplingDefinition
 
toString() - Method in class org.apache.camel.model.ScriptDefinition
 
toString() - Method in class org.apache.camel.model.SetBodyDefinition
 
toString() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
toString() - Method in class org.apache.camel.model.SetFaultBodyDefinition
 
toString() - Method in class org.apache.camel.model.SetHeaderDefinition
 
toString() - Method in class org.apache.camel.model.SetPropertyDefinition
 
toString() - Method in class org.apache.camel.model.SortDefinition
 
toString() - Method in class org.apache.camel.model.SplitDefinition
 
toString() - Method in class org.apache.camel.model.StopDefinition
 
toString() - Method in class org.apache.camel.model.ThreadsDefinition
 
toString() - Method in class org.apache.camel.model.ThrottleDefinition
 
toString() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
toString() - Method in class org.apache.camel.model.ToDefinition
 
toString() - Method in class org.apache.camel.model.ToDynamicDefinition
 
toString() - Method in class org.apache.camel.model.TransactedDefinition
 
toString() - Method in class org.apache.camel.model.TransformDefinition
 
toString() - Method in class org.apache.camel.model.TryDefinition
 
toString() - Method in class org.apache.camel.model.UnmarshalDefinition
 
toString() - Method in class org.apache.camel.model.ValidateDefinition
 
toString() - Method in class org.apache.camel.model.WhenDefinition
 
toString() - Method in class org.apache.camel.model.WireTapDefinition
 
toString() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
toString() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
toString() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.CamelInternalProcessor
 
toString() - Method in class org.apache.camel.processor.CatchProcessor
 
toString() - Method in class org.apache.camel.processor.ChoiceProcessor
 
toString() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
toString() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
toString() - Method in class org.apache.camel.processor.DeadLetterChannel
 
toString() - Method in class org.apache.camel.processor.DefaultErrorHandler
 
toString() - Method in class org.apache.camel.processor.Delayer
 
toString() - Method in class org.apache.camel.processor.Enricher
 
toString() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
toString() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
toString() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
toString() - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
 
toString() - Method in class org.apache.camel.processor.FilterProcessor
 
toString() - Method in class org.apache.camel.processor.FinallyProcessor
 
toString() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
toString() - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
toString() - Method in class org.apache.camel.processor.InterceptEndpointProcessor
 
toString() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
toString() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
 
toString() - Method in class org.apache.camel.processor.interceptor.HandleFault
 
toString() - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
toString() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
toString() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
toString() - Method in class org.apache.camel.processor.LogProcessor
 
toString() - Method in class org.apache.camel.processor.LoopProcessor
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor
 
toString() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
toString() - Method in class org.apache.camel.processor.Pipeline
 
toString() - Method in class org.apache.camel.processor.PollEnricher
 
toString() - Method in class org.apache.camel.processor.RecipientList
 
toString() - Method in class org.apache.camel.processor.RecipientListProcessor
 
toString() - Method in class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryState
 
toString() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
toString() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
toString() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
toString() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
toString() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
toString() - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
toString() - Method in class org.apache.camel.processor.Resequencer
 
toString() - Method in class org.apache.camel.processor.RollbackProcessor
 
toString() - Method in class org.apache.camel.processor.RoutingSlip
 
toString() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
toString() - Method in class org.apache.camel.processor.SamplingThrottler
 
toString() - Method in class org.apache.camel.processor.ScriptProcessor
 
toString() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
toString() - Method in class org.apache.camel.processor.SendProcessor
 
toString() - Method in class org.apache.camel.processor.SetBodyProcessor
 
toString() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
toString() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
toString() - Method in class org.apache.camel.processor.SortProcessor
 
toString() - Method in class org.apache.camel.processor.Splitter
 
toString() - Method in class org.apache.camel.processor.StepProcessor
 
toString() - Method in class org.apache.camel.processor.StopProcessor
 
toString() - Method in class org.apache.camel.processor.StreamResequencer
 
toString() - Method in class org.apache.camel.processor.ThreadsProcessor
 
toString() - Method in class org.apache.camel.processor.Throttler
 
toString() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
toString() - Method in class org.apache.camel.processor.TransformProcessor
 
toString() - Method in class org.apache.camel.processor.TryProcessor
 
toString() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
toString() - Method in class org.apache.camel.processor.WireTapProcessor
 
toString() - Method in class org.apache.camel.processor.WrapProcessor
 
toType(String) - Method in class org.apache.camel.builder.TransformerBuilder
Set the 'to' data type name.
toType(Class<?>) - Method in class org.apache.camel.builder.TransformerBuilder
Set the 'to' data type using Java class.
toXml(int) - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
Dumps the event message as XML using the BacklogTracerEventMessage.ROOT_TAG as root tag.
trace - Variable in class org.apache.camel.main.MainSupport
 
traceEvent(DefaultBacklogTracerEventMessage) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
traceLabelToString - Variable in class org.apache.camel.processor.SendProcessor
 
tracing() - Method in class org.apache.camel.model.RouteDefinition
Enable tracing for this route.
tracing(String) - Method in class org.apache.camel.model.RouteDefinition
Enable tracing for this route.
trackTimeout(String, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
transacted() - Method in class org.apache.camel.model.ProcessorDefinition
Marks this route as transacted and uses the default transacted policy found in the registry.
transacted(String) - Method in class org.apache.camel.model.ProcessorDefinition
Marks this route as transacted.
TransactedDefinition - Class in org.apache.camel.model
Enables transaction on the route
TransactedDefinition() - Constructor for class org.apache.camel.model.TransactedDefinition
 
TransactedDefinition(Policy) - Constructor for class org.apache.camel.model.TransactedDefinition
 
TransactedReifier - Class in org.apache.camel.reifier
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
Perform data transformation with specified from/to type using DataFormat.
transform(Message, DataType, DataType) - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
Perform data transformation with specified from/to type using Processor.
transform(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the OUT message
transform() - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the OUT message
TransformDefinition - Class in org.apache.camel.model
Transforms the message body based on an expression
TransformDefinition() - Constructor for class org.apache.camel.model.TransformDefinition
 
TransformDefinition(Expression) - Constructor for class org.apache.camel.model.TransformDefinition
 
transformer() - Method in class org.apache.camel.builder.RouteBuilder
Create a new TransformerBuilder.
TransformerBuilder - Class in org.apache.camel.builder
A Java DSL which is used to build a Transformer and register into CamelContext.
TransformerBuilder() - Constructor for class org.apache.camel.builder.TransformerBuilder
 
TransformerDefinition - Class in org.apache.camel.model.transformer
Represents a Transformer which declaratively transforms message content according to the input type declared by InputTypeDefinition and/or output type declared by OutputTypeDefinition.
TransformerDefinition() - Constructor for class org.apache.camel.model.transformer.TransformerDefinition
 
TransformerKey - Class in org.apache.camel.impl.transformer
Key used in TransformerRegistry in DefaultCamelContext, to ensure a consistent lookup.
TransformerKey(String) - Constructor for class org.apache.camel.impl.transformer.TransformerKey
 
TransformerKey(DataType, DataType) - Constructor for class org.apache.camel.impl.transformer.TransformerKey
 
TransformerReifier<T> - Class in org.apache.camel.reifier.transformer
 
TransformerReifier(T) - Constructor for class org.apache.camel.reifier.transformer.TransformerReifier
 
TransformersDefinition - Class in org.apache.camel.model.transformer
To configure transformers.
TransformersDefinition() - Constructor for class org.apache.camel.model.transformer.TransformersDefinition
 
TransformProcessor - Class in org.apache.camel.processor
A processor which sets the body on the OUT message with an Expression.
TransformProcessor(Expression) - Constructor for class org.apache.camel.processor.TransformProcessor
 
trunkStore() - Method in class org.apache.camel.impl.FileStateRepository
Trunks the file store when the max store size is hit by rewriting the 1st level cache to the file store.
trustCerts(boolean) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets whether to turn on trust certificate check when using client lookup
TryDefinition - Class in org.apache.camel.model
Marks the beginning of a try, catch, finally block
TryDefinition() - Constructor for class org.apache.camel.model.TryDefinition
 
TryProcessor - Class in org.apache.camel.processor
Implements try/catch/finally type processing
TryProcessor(Processor, List<Processor>, Processor) - Constructor for class org.apache.camel.processor.TryProcessor
 
tryProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
type(String) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the data type name.
type(Class<?>) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the data type using Java class.
type(Class<? extends ServiceRegistry>) - Static method in class org.apache.camel.impl.cloud.ServiceRegistrySelectors
 
type(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
To set the discovery type, valid values are on-demand and watch.
type - Variable in class org.apache.camel.model.PolicyDefinition
 
type(Class<?>) - Method in class org.apache.camel.model.rest.RestDefinition
 
type(RestParamType) - Method in class org.apache.camel.model.rest.RestOperationParamDefinition
The parameter type such as body, form, header, path, query
type - Variable in class org.apache.camel.model.TransactedDefinition
 
typeConverterExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the type converter
TypedProcessorFactory<T extends ProcessorDefinition<T>> - Class in org.apache.camel.impl
 
TypedProcessorFactory(Class<T>) - Constructor for class org.apache.camel.impl.TypedProcessorFactory
 
typeExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a type value

U

UnaryExpression - Class in org.apache.camel.language.simple.ast
Represents an unary expression in the AST
UnaryExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.UnaryExpression
 
unaryOperator() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
unaryOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
UnaryOperatorType - Enum in org.apache.camel.language.simple.types
Types of unary operators supported.
UNINITIALIZED_EXIT_CODE - Static variable in class org.apache.camel.main.MainSupport
 
UnitOfWorkProcessorAdvice(RouteContext) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
UnitOfWorkProducer - Class in org.apache.camel.processor
Ensures a Producer is executed within an UnitOfWork.
UnitOfWorkProducer(Producer) - Constructor for class org.apache.camel.processor.UnitOfWorkProducer
The producer which should be executed within an UnitOfWork.
units(TimeUnit) - Method in class org.apache.camel.model.cloud.CachingServiceCallServiceDiscoveryConfiguration
Set the time unit for the timeout.
UniVocityAbstractDataFormat - Class in org.apache.camel.model.dataformat
Represents the common parts of all uniVocity DataFormat parsers.
UniVocityAbstractDataFormat() - Constructor for class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
UniVocityAbstractDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.UniVocityAbstractDataFormat
 
UniVocityCsvDataFormat - Class in org.apache.camel.model.dataformat
The uniVocity CSV data format is used for working with CSV (Comma Separated Values) flat payloads.
UniVocityCsvDataFormat() - Constructor for class org.apache.camel.model.dataformat.UniVocityCsvDataFormat
 
UniVocityFixedWidthDataFormat - Class in org.apache.camel.model.dataformat
The uniVocity Fixed Length data format is used for working with fixed length flat payloads.
UniVocityFixedWidthDataFormat() - Constructor for class org.apache.camel.model.dataformat.UniVocityFixedWidthDataFormat
 
UniVocityHeader - Class in org.apache.camel.model.dataformat
To configure headers for UniVocity data formats.
UniVocityHeader() - Constructor for class org.apache.camel.model.dataformat.UniVocityHeader
 
UniVocityTsvDataFormat - Class in org.apache.camel.model.dataformat
The uniVocity TSV data format is used for working with TSV (Tabular Separated Values) flat payloads.
UniVocityTsvDataFormat() - Constructor for class org.apache.camel.model.dataformat.UniVocityTsvDataFormat
 
unmanageObject(Object) - Method in class org.apache.camel.impl.DefaultManagementStrategy
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.GzipDataFormat
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.SerializationDataFormat
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.StringDataFormat
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.ZipDataFormat
 
unmarshal(XStreamDataFormat.AliasList) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasAdapter
 
unmarshal(XStreamDataFormat.ConverterList) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConvertersAdapter
 
unmarshal(XStreamDataFormat.ImplicitCollectionList) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionsAdapter
 
unmarshal(XStreamDataFormat.OmitFieldList) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldsAdapter
 
unmarshal() - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Unmarshals the in body using a DataFormat expression to define the format of the input message and the output will be set on the out message body.
unmarshal(DataFormatDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Unmarshals the in body using the specified DataFormat and sets the output on the out message body.
unmarshal(DataFormat) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Unmarshals the in body using the specified DataFormat and sets the output on the out message body.
unmarshal(String) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Unmarshals the in body using the specified DataFormat reference in the Registry and sets the output on the out message body.
unmarshal(String) - Method in class org.apache.camel.model.TimeUnitAdapter
 
UnmarshalDefinition - Class in org.apache.camel.model
Converts the message data received from the wire into a format that Apache Camel processors can consume
UnmarshalDefinition() - Constructor for class org.apache.camel.model.UnmarshalDefinition
 
UnmarshalDefinition(DataFormatDefinition) - Constructor for class org.apache.camel.model.UnmarshalDefinition
 
unwrap(CamelInternalProcessorAdvice<?>) - Static method in interface org.apache.camel.processor.CamelInternalProcessorAdvice
 
updateNewExchange(Exchange, int, Iterable<ProcessorExchangePair>, boolean) - Method in class org.apache.camel.processor.MulticastProcessor
 
updateNewExchange(Exchange, int, Iterable<ProcessorExchangePair>, boolean) - Method in class org.apache.camel.processor.Splitter
 
uri(String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
Sets the uri of the service to use
uri(String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
Sets the uri of the service to use
uri - Variable in class org.apache.camel.model.InterceptFromDefinition
 
uri - Variable in class org.apache.camel.model.SendDefinition
 
uri - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
uriDelimiter(String) - Method in class org.apache.camel.model.DynamicRouterDefinition
Sets the uri delimiter to use
uriDelimiter(String) - Method in class org.apache.camel.model.RoutingSlipDefinition
Sets the uri delimiter to use
uriDelimiter - Variable in class org.apache.camel.processor.RoutingSlip
 
uris(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The URIs the client can connect to.
url(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
The Consul agent URL
useCollisionAvoidance() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useCollisionAvoidance() - Method in class org.apache.camel.model.OnExceptionDefinition
Turn on collision avoidance.
useCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Turn on collision avoidance.
useCollisionAvoidance - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
useExponentialBackOff() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useExponentialBackOff() - Method in class org.apache.camel.model.OnExceptionDefinition
Turn on exponential back off
useExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Turn on exponential backk off
useExponentialBackOff - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
useLatest() - Static method in class org.apache.camel.builder.AggregationStrategies
Use the latest incoming exchange.
UseLatestAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which just uses the latest exchange which is useful for status messages where old status messages have no real value.
UseLatestAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
useOriginal() - Static method in class org.apache.camel.builder.AggregationStrategies
Use the original exchange.
useOriginal(boolean) - Static method in class org.apache.camel.builder.AggregationStrategies
Use the original exchange.
UseOriginalAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which just uses the original exchange which can be needed when you want to preserve the original Exchange.
UseOriginalAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
UseOriginalAggregationStrategy(boolean) - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
UseOriginalAggregationStrategy(Exchange, boolean) - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
useOriginalBody() - Method in class org.apache.camel.model.OnCompletionDefinition
Will use the original input body when an Exchange for this on completion.
useOriginalMessage - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useOriginalMessage() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Will use the original input Message when an Exchange is moved to the dead letter queue.
useOriginalMessage() - Method in class org.apache.camel.model.OnExceptionDefinition
Will use the original input message when an Exchange is moved to the dead letter queue.
useOriginalMessagePolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
userName(String) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Sets the username to be used for basic authentication
userName(String) - Method in class org.apache.camel.model.cloud.EtcdServiceCallServiceDiscoveryConfiguration
The user name to use for basic authentication.
username(String) - Method in class org.apache.camel.model.cloud.KubernetesServiceCallServiceDiscoveryConfiguration
Sets the username for authentication when using client lookup
username(String) - Method in class org.apache.camel.model.cloud.RibbonServiceCallServiceLoadBalancerConfiguration
Sets the username
useXForwardHeaders(boolean) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To specify whether to use X-Forward headers for Host and related setting

V

validate(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a validation expression which only if it is true then the exchange is forwarded to the destination.
validate(Predicate) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a validation expression which only if it is true then the exchange is forwarded to the destination.
validate() - Method in class org.apache.camel.model.ProcessorDefinition
Creates a validation expression which only if it is true then the exchange is forwarded to the destination.
validateConfiguration() - Method in class org.apache.camel.model.OnExceptionDefinition
 
validateDeadLetterUri(RouteContext) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
ValidateDefinition - Class in org.apache.camel.model
Validates a message based on an expression
ValidateDefinition() - Constructor for class org.apache.camel.model.ValidateDefinition
 
ValidateDefinition(Expression) - Constructor for class org.apache.camel.model.ValidateDefinition
 
ValidateDefinition(Predicate) - Constructor for class org.apache.camel.model.ValidateDefinition
 
validateHasMethod(CamelContext, Object, Class<?>, String) - Method in class org.apache.camel.model.language.MethodCallExpression
Validates the given bean has the method.
validateUniqueIds(RouteDefinition, List<RouteDefinition>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
Validates that the target route has no duplicate id's from any of the existing routes.
validateUniquePaths() - Method in class org.apache.camel.model.rest.RestDefinition
 
validator() - Method in class org.apache.camel.builder.RouteBuilder
Create a new ValidatorBuilder.
ValidatorBuilder - Class in org.apache.camel.builder
A Java DSL which is used to build a Validator and register into CamelContext.
ValidatorBuilder() - Constructor for class org.apache.camel.builder.ValidatorBuilder
 
ValidatorDefinition - Class in org.apache.camel.model.validator
Represents a Validator which declaratively validates message content according to the input type declared by InputTypeDefinition and/or output type declared by OutputTypeDefinition.
ValidatorDefinition() - Constructor for class org.apache.camel.model.validator.ValidatorDefinition
 
ValidatorReifier<T> - Class in org.apache.camel.reifier.validator
 
ValidatorsDefinition - Class in org.apache.camel.model.validator
To configure validators.
ValidatorsDefinition() - Constructor for class org.apache.camel.model.validator.ValidatorsDefinition
 
ValueBuilder - Class in org.apache.camel.builder
A builder of expressions or predicates based on values.
ValueBuilder(Expression) - Constructor for class org.apache.camel.builder.ValueBuilder
 
valueOf(String) - Static method in enum org.apache.camel.builder.DataFormatClause.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.impl.AbstractCamelContext.Initialization
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.TokenType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.ClaimCheckOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.BindyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.JsonLibrary
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.YAMLLibrary
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.YAMLTypeFilterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.OnCompletionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.rest.CollectionFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.rest.RestBindingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.rest.RestHostNameResolver
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.rest.RestParamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.SagaCompletionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.SagaPropagation
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.builder.DataFormatClause.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.impl.AbstractCamelContext.Initialization
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.TokenType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.ClaimCheckOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.dataformat.BindyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.dataformat.JsonLibrary
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.dataformat.YAMLLibrary
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.dataformat.YAMLTypeFilterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.OnCompletionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.rest.CollectionFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.rest.RestBindingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.rest.RestHostNameResolver
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.rest.RestParamType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.SagaCompletionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.model.SagaPropagation
Returns an array containing the constants of this enum type, in the order they are declared.
variable(String, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers a variable (in the global namespace) which can be referred to from XPath expressions
verb(String) - Method in class org.apache.camel.model.rest.RestDefinition
 
verb(String, String) - Method in class org.apache.camel.model.rest.RestDefinition
 
verb(String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
verb(String, String) - Method in class org.apache.camel.model.rest.VerbDefinition
 
VerbDefinition - Class in org.apache.camel.model.rest
Rest command
VerbDefinition() - Constructor for class org.apache.camel.model.rest.VerbDefinition
 

W

waitForCompleteLatch(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
waitForCompleteLatch() - Method in class org.apache.camel.component.mock.MockEndpoint
 
waitForCompleteLatch(long) - Method in class org.apache.camel.component.mock.MockEndpoint
 
waitUntilCompleted() - Method in class org.apache.camel.main.MainSupport
 
warmUp() - Method in class org.apache.camel.impl.DefaultRoute
 
warmUp() - Method in class org.apache.camel.impl.RouteService
 
weaveAddFirst() - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by adding the nodes to the start of the route (excl onException etc).
weaveAddLast() - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by adding the nodes to the end of the route (excl onException etc).
weaveById(String) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by matching id of the nodes in the route (incl onException etc).
weaveByToString(String) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by matching the to string representation of the nodes in the route (incl onException etc).
weaveByToUri(String) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by matching sending to endpoints with the given uri of the nodes in the route (incl onException etc).
weaveByType(Class<T>) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
Weaves by matching type of the nodes in the route (incl onException etc).
WebSpherePackageScanClassResolver - Class in org.apache.camel.impl
WebSphere specific resolver to handle loading annotated resources in JAR files.
WebSpherePackageScanClassResolver(String) - Constructor for class org.apache.camel.impl.WebSpherePackageScanClassResolver
Constructor.
weighted(boolean, String) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses weighted load balancer
weighted(boolean, String, String) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses weighted load balancer
WeightedLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
WeightedLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Weighted load balancer The weighted load balancing policy allows you to specify a processing load distribution ratio for each server with respect to others.
WeightedLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
 
WeightedRandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedRandomLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedRandomLoadBalancer
 
WeightedRoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedRoundRobinLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
wereSentTo(String) - Method in class org.apache.camel.builder.NotifyBuilder
Optionally a sent to endpoint which means that this expression should only be based on Exchange which has been sent to the given endpoint uri.
when(Predicate) - Method in class org.apache.camel.model.ChoiceDefinition
Sets the predicate for the when node
when() - Method in class org.apache.camel.model.ChoiceDefinition
Creates an expression for the when node
when(Predicate) - Method in class org.apache.camel.model.InterceptDefinition
Applies this interceptor only if the given predicate is true
when(Predicate) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
Applies this interceptor only if the given predicate is true
whenAllDoneMatches(Predicate) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that all done Exchange should match the Predicate
whenAllReceivedMatches(Predicate) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that all received Exchange should match the Predicate
whenAnyDoneMatches(Predicate) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that any done Exchange should match the Predicate
whenAnyExchangeReceived(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the processor that will be invoked when the some message is received.
whenAnyReceivedMatches(Predicate) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that any received Exchange should match the Predicate
whenBodiesDone(Object...) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that the bodies is expected to be done in the order as well.
whenBodiesReceived(Object...) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that the bodies is expected to be received in the order as well.
whenCompleted(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange has been completed.
WhenDefinition - Class in org.apache.camel.model
Triggers a route when an expression evaluates to true
WhenDefinition() - Constructor for class org.apache.camel.model.WhenDefinition
 
WhenDefinition(Predicate) - Constructor for class org.apache.camel.model.WhenDefinition
 
WhenDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.WhenDefinition
 
whenDone(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange is done being processed.
whenDoneByIndex(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when tne n'th (by index) Exchange is done being processed.
whenDoneNotSatisfied(MockEndpoint) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when the provided mock is not satisfied based on Exchange being sent to it when they are done.
whenDoneSatisfied(MockEndpoint) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when the provided mock is satisfied based on Exchange being sent to it when they are done.
whenExactBodiesDone(Object...) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that the bodies is expected to be done in the order as well.
whenExactBodiesReceived(Object...) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition that the bodies is expected to be received in the order as well.
whenExactlyCompleted(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange has been completed.
whenExactlyDone(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange is done being processed.
whenExactlyFailed(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange has failed.
whenExchangeReceived(int, Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the processor that will be invoked when the index message is received.
whenFailed(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange has failed.
whenReceived(int) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when number of Exchange has been received.
whenReceivedNotSatisfied(MockEndpoint) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when the provided mock is not satisfied based on Exchange being sent to it when they are received.
whenReceivedSatisfied(MockEndpoint) - Method in class org.apache.camel.builder.NotifyBuilder
Sets a condition when the provided mock is satisfied based on Exchange being sent to it when they are received.
WhenSkipSendToEndpointDefinition - Class in org.apache.camel.model
Predicate to determine if the message should be sent or not to the endpoint, when using interceptSentToEndpoint.
WhenSkipSendToEndpointDefinition() - Constructor for class org.apache.camel.model.WhenSkipSendToEndpointDefinition
 
willCreateNewThreadPool(RouteContext, ExecutorServiceAwareDefinition<?>, boolean) - Static method in class org.apache.camel.model.ProcessorDefinitionHelper
Determines whether a new thread pool will be created or not.
wireTap(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
WireTap EIP: Sends messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other using ExchangePattern.InOnly.
wireTap(String) - Method in class org.apache.camel.model.ProcessorDefinition
WireTap EIP: Sends messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other using ExchangePattern.InOnly.
WireTapDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
Routes a copy of a message (or creates a new message) to a secondary destination while continue routing the original message.
WireTapDefinition() - Constructor for class org.apache.camel.model.WireTapDefinition
 
WireTapProcessor - Class in org.apache.camel.processor
Processor for wire tapping exchanges to an endpoint destination.
WireTapProcessor(SendDynamicProcessor, Processor, ExchangePattern, ExecutorService, boolean, boolean) - Constructor for class org.apache.camel.processor.WireTapProcessor
 
withBean(String) - Method in class org.apache.camel.builder.TransformerBuilder
Set the Java Bean name to be used for custom Transformer.
withBean(String) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the Java Bean name to be used for custom Validator.
withBody(Object) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withBody(Object) - Method in class org.apache.camel.builder.ExchangeBuilder
Set the in message body on the exchange
withBodyAs(Object, Class<?>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withDataFormat(DataFormatDefinition) - Method in class org.apache.camel.builder.TransformerBuilder
Set the DataFormatDefinition to be used for the DataFormat Transformer.
withExchange(Exchange) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withExchange(Supplier<Exchange>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withExpression(Expression) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the Expression to be used for the predicate Validator.
withExpression(Predicate) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the Predicate to be used for the predicate Validator.
withHeader(String, Object) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withHeader(String, Object) - Method in class org.apache.camel.builder.ExchangeBuilder
Set the message header of the in message on the exchange
withHeader(String) - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
withHealth(ServiceHealth) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withHost(String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withId(String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withJava(Class<? extends Transformer>) - Method in class org.apache.camel.builder.TransformerBuilder
Set the Java Class represents a custom Transformer implementation class.
withJava(Class<? extends Validator>) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the Java Class represents a custom Validator implementation class.
withMeta(Map<String, String>) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withName(String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withPattern(ExchangePattern) - Method in class org.apache.camel.builder.ExchangeBuilder
Set the message exchange pattern on the exchange
withPort(Integer) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withPort(String) - Method in class org.apache.camel.impl.cloud.DefaultServiceDefinition.Builder
 
withProcessor(Processor) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withProcessor(Supplier<Processor>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withProperty(String, Object) - Method in class org.apache.camel.builder.ExchangeBuilder
Set the exchange property
withQuery(String) - Method in class org.apache.camel.model.rest.RestSecurityApiKey
 
withScope(String, String) - Method in class org.apache.camel.model.rest.RestSecurityOAuth2
 
withTemplateCustomizer(Consumer<ProducerTemplate>) - Method in class org.apache.camel.builder.DefaultFluentProducerTemplate
 
withUri(String) - Method in class org.apache.camel.builder.TransformerBuilder
Set the URI to be used for the endpoint Transformer.
withUri(String) - Method in class org.apache.camel.builder.ValidatorBuilder
Set the URI to be used for the endpoint Validator.
wrap(ServiceDiscovery) - Static method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
wrap(ServiceDiscovery, long) - Static method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
wrap(ServiceDiscovery, long, TimeUnit) - Static method in class org.apache.camel.impl.cloud.CachingServiceDiscovery
 
wrap(ServiceDiscovery...) - Static method in class org.apache.camel.impl.cloud.CombinedServiceDiscovery
 
wrap(ServiceFilter...) - Static method in class org.apache.camel.impl.cloud.CombinedServiceFilter
 
wrap(ManagementInterceptStrategy.InstrumentationProcessor<T>) - Static method in interface org.apache.camel.processor.CamelInternalProcessorAdvice
Wrap an InstrumentationProcessor into a CamelInternalProcessorAdvice
wrapChannel(RouteContext, Processor, ProcessorDefinition<?>) - Method in class org.apache.camel.reifier.ProcessorReifier
 
wrapChannel(RouteContext, Processor, ProcessorDefinition<?>, Boolean) - Method in class org.apache.camel.reifier.ProcessorReifier
 
wrapInErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.reifier.ProcessorReifier
Wraps the given output in an error handler
WrapProcessor - Class in org.apache.camel.processor
A processor which ensures wrapping processors is having lifecycle handled.
WrapProcessor(Processor, Processor) - Constructor for class org.apache.camel.processor.WrapProcessor
 
wrapProcessor(RouteContext, Processor) - Method in class org.apache.camel.reifier.ProcessorReifier
Wraps the child processor in whatever necessary interceptors and error handlers
wrapProcessorInInterceptors(CamelContext, NamedNode, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.Debug
 
wrapProcessorInInterceptors(CamelContext, NamedNode, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.HandleFault
 
writeExternal(ObjectOutput) - Method in class org.apache.camel.component.bean.BeanInvocation
 
writeTimeoutMillis(Long) - Method in class org.apache.camel.model.cloud.ConsulServiceCallServiceDiscoveryConfiguration
Write timeout for OkHttpClient

X

xmlDataFormat(String) - Method in class org.apache.camel.model.rest.RestConfigurationDefinition
To use a specific XML data format

Important: This option is only for setting a custom name of the data format, not to refer to an existing data format instance.

XmlRpcDataFormat - Class in org.apache.camel.model.dataformat
The XML RPC data format is used for working with the XML RPC protocol.
XmlRpcDataFormat() - Constructor for class org.apache.camel.model.dataformat.XmlRpcDataFormat
 
XMLSecurityDataFormat - Class in org.apache.camel.model.dataformat
The XML Security data format facilitates encryption and decryption of XML payloads.
XMLSecurityDataFormat() - Constructor for class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
XMLTokenExpressionIterator - Class in org.apache.camel.builder
An XMLTokenizeLanguage based iterator.
XMLTokenExpressionIterator(String, char) - Constructor for class org.apache.camel.builder.XMLTokenExpressionIterator
 
XMLTokenExpressionIterator(String, char, int) - Constructor for class org.apache.camel.builder.XMLTokenExpressionIterator
 
XMLTokenizeLanguage - Class in org.apache.camel.language.tokenizer
A language for tokenizer expressions.
XMLTokenizeLanguage() - Constructor for class org.apache.camel.language.tokenizer.XMLTokenizeLanguage
 
XMLTokenizerExpression - Class in org.apache.camel.model.language
To use Camel message body or header with a XML tokenizer in Camel expressions or predicates.
XMLTokenizerExpression() - Constructor for class org.apache.camel.model.language.XMLTokenizerExpression
 
XMLTokenizerExpression(String) - Constructor for class org.apache.camel.model.language.XMLTokenizerExpression
 
xpath(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a xpath expression value builder
xpath(String, Class<?>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a xpath expression value builder
xpath(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression
xpath(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression on the supplied header name's contents
xpath(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type
xpath(String, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type on the supplied header name's contents
xpath(String, Class<?>, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Class<?>, Namespaces, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs on the supplied header name's contents
xpath(String, Class<?>, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression
xpath(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression on the supplied header name's contents
xpath(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified result type
xpath(String, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified result type on the supplied header name's contents
xpath(String, Class<?>, Namespaces) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Class<?>, Namespaces, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs on the supplied header name's contents
xpath(String, Class<?>, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String) - Static method in class org.apache.camel.builder.xml.XPathBuilder
 
xpath(String, Class<?>) - Static method in class org.apache.camel.builder.xml.XPathBuilder
 
XPath - Annotation Type in org.apache.camel.language
Used to inject an XPath expression into a field, property, method or parameter when using Bean Integration.
XPathAnnotationExpressionFactory - Class in org.apache.camel.component.bean
Factory for the XPath expression annotations.
XPathAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
XPathBuilder - Class in org.apache.camel.builder.xml
Creates an XPath expression builder which creates a nodeset result by default.
XPathBuilder(String) - Constructor for class org.apache.camel.builder.xml.XPathBuilder
 
XPathExpression - Class in org.apache.camel.model.language
To use XPath (XML) in Camel expressions or predicates.
XPathExpression() - Constructor for class org.apache.camel.model.language.XPathExpression
 
XPathExpression(String) - Constructor for class org.apache.camel.model.language.XPathExpression
 
XPathExpression(Expression) - Constructor for class org.apache.camel.model.language.XPathExpression
 
XPathLanguage - Class in org.apache.camel.language.xpath
XPath language.
XPathLanguage() - Constructor for class org.apache.camel.language.xpath.XPathLanguage
 
xquery(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression
xquery(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression on the supplied header name's contents
xquery(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type
xquery(String, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type
xquery(String, Class<?>, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Class<?>, Namespaces, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type
xquery(String, Class<?>, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
xquery(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
xquery(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression
xquery(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression
xquery(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified result type
xquery(String, Class<?>, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified result type
xquery(String, Class<?>, Namespaces) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Class<?>, Namespaces, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Class<?>, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
xquery(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
XQueryExpression - Class in org.apache.camel.model.language
To use XQuery (XML) in Camel expressions or predicates.
XQueryExpression() - Constructor for class org.apache.camel.model.language.XQueryExpression
 
XQueryExpression(String) - Constructor for class org.apache.camel.model.language.XQueryExpression
 
xstream() - Method in class org.apache.camel.builder.DataFormatClause
Uses the XStream data format.
xstream(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the xstream by setting the encoding or permission
xstream(String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the xstream by setting the encoding
xstream(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the xstream by permitting the java type
xstream(String, Class<?>...) - Method in class org.apache.camel.builder.DataFormatClause
Uses the xstream by permitting the java type
XStreamDataFormat - Class in org.apache.camel.model.dataformat
XSTream data format is used for unmarshal a XML payload to POJO or to marshal POJO back to XML payload.
XStreamDataFormat() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat
 
XStreamDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat
 
XStreamDataFormat.AliasAdapter - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.AliasEntry - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.AliasList - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ConverterEntry - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ConverterList - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ConvertersAdapter - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ImplicitCollectionEntry - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ImplicitCollectionList - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.ImplicitCollectionsAdapter - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.OmitFieldEntry - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.OmitFieldList - Class in org.apache.camel.model.dataformat
 
XStreamDataFormat.OmitFieldsAdapter - Class in org.apache.camel.model.dataformat
 
xtokenize(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
 
xtokenize(String, char, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
 
xtokenize(String, char, Namespaces, int) - Method in class org.apache.camel.builder.ExpressionClause
 
xtokenize(String, char, Namespaces, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
Evaluates an XML token expression on the message body with XML content
xtokenize(String, Namespaces) - Method in class org.apache.camel.builder.ValueBuilder
 
xtokenize(String, char, Namespaces) - Method in class org.apache.camel.builder.ValueBuilder
 

Y

yaml(YAMLLibrary) - Method in class org.apache.camel.builder.DataFormatClause
Uses the YAML data format
yaml(YAMLLibrary, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the YAML data format
YAMLDataFormat - Class in org.apache.camel.model.dataformat
YAML is a data format to marshal and unmarshal Java objects to and from YAML.
YAMLDataFormat() - Constructor for class org.apache.camel.model.dataformat.YAMLDataFormat
 
YAMLDataFormat(YAMLLibrary) - Constructor for class org.apache.camel.model.dataformat.YAMLDataFormat
 
YAMLDataFormat(YAMLLibrary, Class<?>) - Constructor for class org.apache.camel.model.dataformat.YAMLDataFormat
 
YAMLLibrary - Enum in org.apache.camel.model.dataformat
Represents the concrete Yaml libraries Camel supports.
YAMLTypeFilterDefinition - Class in org.apache.camel.model.dataformat
 
YAMLTypeFilterDefinition() - Constructor for class org.apache.camel.model.dataformat.YAMLTypeFilterDefinition
 
YAMLTypeFilterType - Enum in org.apache.camel.model.dataformat
 

Z

zip() - Method in class org.apache.camel.builder.DataFormatClause
Uses the ZIP deflater data format
zip(int) - Method in class org.apache.camel.builder.DataFormatClause
Uses the ZIP deflater data format
ZipDataFormat - Class in org.apache.camel.impl
"Deflate" compression data format.
ZipDataFormat() - Constructor for class org.apache.camel.impl.ZipDataFormat
 
ZipDataFormat(int) - Constructor for class org.apache.camel.impl.ZipDataFormat
 
ZipDataFormat - Class in org.apache.camel.model.dataformat
Zip Deflate Compression data format is a message compression and de-compression format (not zip files).
ZipDataFormat() - Constructor for class org.apache.camel.model.dataformat.ZipDataFormat
 
ZipDataFormat(int) - Constructor for class org.apache.camel.model.dataformat.ZipDataFormat
 
zipFile() - Method in class org.apache.camel.builder.DataFormatClause
Uses the ZIP file data format
ZipFileDataFormat - Class in org.apache.camel.model.dataformat
The Zip File data format is a message compression and de-compression format of zip files.
ZipFileDataFormat() - Constructor for class org.apache.camel.model.dataformat.ZipFileDataFormat
 
ZooKeeperServiceCallServiceDiscoveryConfiguration - Class in org.apache.camel.model.cloud
 
ZooKeeperServiceCallServiceDiscoveryConfiguration() - Constructor for class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
ZooKeeperServiceCallServiceDiscoveryConfiguration(ServiceCallDefinition) - Constructor for class org.apache.camel.model.cloud.ZooKeeperServiceCallServiceDiscoveryConfiguration
 
zookeeperServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
zookeeperServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallConfigurationDefinition
 
zookeeperServiceDiscovery() - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
zookeeperServiceDiscovery(String, String) - Method in class org.apache.camel.model.cloud.ServiceCallDefinition
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

Apache Camel