Index

A B C D E F G H I L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

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
 
AbstractThrottler - Class in org.apache.camel.processor
 
AbstractThrottler.State - Enum Class in org.apache.camel.processor
 
acceptClass(Class<?>) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
acquire() - Method in class org.apache.camel.processor.PooledTaskFactory
 
acquire() - Method in class org.apache.camel.processor.PrototypeTaskFactory
 
acquire(Exchange, AsyncCallback) - Method in interface org.apache.camel.processor.PooledExchangeTaskFactory
Attempts to acquire a pooled task to use for processing the exchange, if not possible then a new task is created.
acquire(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.PooledTaskFactory
 
acquire(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.PrototypeTaskFactory
 
add(String, Exchange) - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
add(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
add(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
addChildUnitOfWorkProcessorAdvice(CamelContext, Processor, Route, UnitOfWork) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
addErrorHandler(Processor) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
addExceptionPolicy(ExceptionPolicyKey, ExceptionPolicy) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
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
 
addUnitOfWorkProcessorAdvice(CamelContext, Processor, Route) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
after(Exchange, Object) - Method in class org.apache.camel.processor.ContractAdvice
 
after(Exchange, Map<String, Object>) - Method in class org.apache.camel.processor.RestBindingAdvice
 
afterSend(ProcessorExchangePair, StopWatch) - Method in class org.apache.camel.processor.MulticastProcessor
 
aggregate() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTask
 
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.AggregationStrategyBiFunctionAdapter
 
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.StringAggregationStrategy
 
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(Exchange, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
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 - Interface in org.apache.camel.processor.aggregate
A controller which allows controlling a AggregateProcessor from an external source, such as Java API or JMX.
AggregateProcessor - Class in org.apache.camel.processor.aggregate
An implementation of the Aggregator pattern where a batch of messages is processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined 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
AggregationStrategyBeanAdapter - Class in org.apache.camel.processor.aggregate
An AggregationStrategy that adapts to a POJO.
AggregationStrategyBeanAdapter(Class<?>) - 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.
AggregationStrategyBeanAdapter(Object) - 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.
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
 
AggregationStrategyBiFunctionAdapter - Class in org.apache.camel.processor.aggregate
An AggregationStrategy that adapts to a BiFunction.
AggregationStrategyBiFunctionAdapter(BiFunction<Exchange, Exchange, Object>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBiFunctionAdapter
 
AggregationStrategyMethodInfo - Class in org.apache.camel.processor.aggregate
Method information about the POJO method to call when using the AggregationStrategyBeanAdapter.
AggregationStrategyMethodInfo(Method, List<AggregationStrategyParameterInfo>, List<AggregationStrategyParameterInfo>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
AggregationStrategyParameterInfo - Class in org.apache.camel.processor.aggregate
Parameter information to be used for method invocation.
AggregationStrategyParameterInfo(int, Class<?>, Expression) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
allowOptimisedComponents - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
allowRedeliveryWhileStopping - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
allowRedeliveryWhileStopping - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
allowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
AnnotationTransformerLoader - Class in org.apache.camel.processor.transformer
Transformer loader scans packages for Transformer classes annotated with DataType annotation.
AnnotationTransformerLoader() - Constructor for class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
ASYNC - Enum constant in enum class org.apache.camel.processor.AbstractThrottler.State
 
ASYNC_REJECTED - Enum constant in enum class org.apache.camel.processor.AbstractThrottler.State
 
asyncDelayed - Variable in class org.apache.camel.processor.AbstractThrottler
 
asyncDelayedRedelivery - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
asyncDelayedRedelivery - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
asyncDelayedRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Allow asynchronous delayed redelivery.
asyncExecutor - Variable in class org.apache.camel.processor.AbstractThrottler
 
AUTO - Enum constant in enum class org.apache.camel.processor.saga.SagaCompletionMode
Complete the saga automatically as soon as the exchange is processed.
autoStartupComponents - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
awaitManager - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 

B

backOffMultiplier - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
backOffMultiplier - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
backOffMultiplier(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables exponential backoff and sets the multiplier used to increase the delay between redeliveries
before(Exchange) - Method in class org.apache.camel.processor.ContractAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.RestBindingAdvice
 
beforeSend(ProcessorExchangePair) - Method in class org.apache.camel.processor.MulticastProcessor
 
begin() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
build() - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
ByteArrayDataTypeTransformer - Class in org.apache.camel.processor.transformer
Generic binary data type uses Camel message body converter mechanism to convert content to byte array representation.
ByteArrayDataTypeTransformer() - Constructor for class org.apache.camel.processor.transformer.ByteArrayDataTypeTransformer
 

C

cacheSize - Variable in class org.apache.camel.processor.RoutingSlip
 
cacheSize - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
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.errorhandler.RedeliveryPolicy
Calculates the delay using the delay pattern
calculateRedeliveryDelay(long, int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Calculates the new redelivery delay based on the last one
callerRunsWhenRejected - Variable in class org.apache.camel.processor.AbstractThrottler
 
camelContext - Variable in class org.apache.camel.processor.AbstractThrottler
 
camelContext - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
camelContext - Variable in class org.apache.camel.processor.RoutingSlip
 
camelContext - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
camelContext - Variable in class org.apache.camel.processor.SendProcessor
 
camelContext - Variable in class org.apache.camel.processor.TryProcessor
 
camelContext(CamelContext) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
canPreComplete() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
catchClauses - Variable in class org.apache.camel.processor.TryProcessor
 
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(CamelContext, List<Class<? extends Throwable>>, Processor, Predicate) - Constructor for class org.apache.camel.processor.CatchProcessor
 
changeOutput(Processor) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
checkException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
childProcessor(Processor) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
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
 
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
 
ClaimCheckAggregationStrategy - Class in org.apache.camel.processor
Default AggregationStrategy used by the ClaimCheckProcessor EIP.
ClaimCheckAggregationStrategy() - Constructor for class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
ClaimCheckProcessor - Class in org.apache.camel.processor
ClaimCheck EIP implementation.
ClaimCheckProcessor() - Constructor for class org.apache.camel.processor.ClaimCheckProcessor
 
clear() - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
clear() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Clear the idempotent repository
clearClosedCorrelationKeysCache() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Clear all the closed correlation keys stored in the cache
clone(Processor) - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
clone(Processor) - Method in class org.apache.camel.processor.errorhandler.DefaultErrorHandler
 
clone(Processor) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Clones the current error handler and changes the output
clone(Processor) - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
close() - Method in class org.apache.camel.processor.DefaultProcessorFactory
 
ClosedCorrelationKeyException - Exception Class in org.apache.camel.processor.aggregate
The correlation key has been closed and the Exchange cannot be aggregated.
ClosedCorrelationKeyException(String, Exchange) - Constructor for exception class org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
ClosedCorrelationKeyException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
collisionAvoidanceFactor - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
collisionAvoidanceFactor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables collision avoidance and sets the percentage used
comparator() - Method in class org.apache.camel.processor.resequencer.Sequence
Returns this sequence's comparator.
compare(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
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
 
completionMode - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
completionMode(SagaCompletionMode) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
ConcurrentRequestsThrottler - 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 concurrently.
ConcurrentRequestsThrottler(CamelContext, Expression, ScheduledExecutorService, boolean, boolean, Expression) - Constructor for class org.apache.camel.processor.ConcurrentRequestsThrottler
 
configurationBuilder() - Static method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepositoryConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategyConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicyConfigurer
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.WireTapProcessor
 
configureExchange(Exchange, ExchangePattern, Endpoint) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
confirm(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
contains(String) - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
continueProcessing(Exchange, String, Logger) - Static method in class org.apache.camel.processor.PipelineHelper
Should we continue processing the exchange?
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
 
copy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
copyExchangeStrategy(Processor, Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
Strategy method to copy the exchange before sending to another endpoint.
correlationExpression - Variable in class org.apache.camel.processor.AbstractThrottler
 
counter - Variable in class org.apache.camel.processor.SendProcessor
 
create(Exchange, AsyncCallback) - Method in interface org.apache.camel.processor.PooledExchangeTaskFactory
Creates a new task to use for processing the exchange.
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
 
createChannel(CamelContext) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
createChildProcessor(Route, NamedNode, boolean) - Method in class org.apache.camel.processor.DefaultProcessorFactory
 
createDynamicRouter(CamelContext, DynamicRouter) - Method in class org.apache.camel.processor.DefaultAnnotationBasedProcessorFactory
 
createErrorHandler(Route, Exchange, AsyncProcessor, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
createExceptionIterable(Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy method creating the iterator to walk the exception in the order Camel should use for find the ExceptionPolicyKey should be used.
createInterceptSendToEndpointProcessor(InterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
createMethodInfo() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanInfo
 
createProcessor(CamelContext, String, Object[]) - Method in class org.apache.camel.processor.DefaultProcessorFactory
 
createProcessor(Route, NamedNode) - Method in class org.apache.camel.processor.DefaultProcessorFactory
 
createProcessorExchangePair(int, Endpoint, Producer, Exchange, ExchangePattern, boolean) - Method in class org.apache.camel.processor.RecipientListProcessor
This logic is similar to MulticastProcessor but we have to return a RecipientProcessorExchangePair instead
createProcessorExchangePair(int, Processor, Exchange, Route) - Method in class org.apache.camel.processor.MulticastProcessor
Creates the ProcessorExchangePair which holds the processor and exchange to be send out.
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
 
createProducer(Endpoint) - Method in class org.apache.camel.processor.DefaultDeferServiceFactory
 
createRecipientList(CamelContext, RecipientList) - Method in class org.apache.camel.processor.DefaultAnnotationBasedProcessorFactory
 
createRedeliveryPolicy(CamelContext, RedeliveryPolicy) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
Allows an exception handler to create a new redelivery policy for this exception type
createResourceExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.Enricher
Creates a new DefaultExchange instance from the given exchange.
createRoutingSlip(CamelContext, RoutingSlip) - Method in class org.apache.camel.processor.DefaultAnnotationBasedProcessorFactory
 
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.
createSet(Comparator<? super Exchange>, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSet(Expression, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSharedCamelInternalProcessor(CamelContext) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
createSimpleCache() - Static method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
createUnitOfWorkProcessor(Route, Processor, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Strategy to create the unit of work to be used for the sub route
createUnitOfWorkProducer(Producer) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
createWrapProcessor(Processor, Processor) - Method in class org.apache.camel.processor.DefaultInternalProcessorFactory
 
currentSystemTime() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
customExchangeFormatter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 

D

DATA_TYPE_PROPERTY - Static variable in class org.apache.camel.processor.transformer.DataTypeProcessor
 
DataFormatTransformer - Class in org.apache.camel.processor.transformer
A Transformer implementation which leverages DataFormat to perform transformation.
DataFormatTransformer() - Constructor for class org.apache.camel.processor.transformer.DataFormatTransformer
 
DataFormatTransformer(CamelContext) - Constructor for class org.apache.camel.processor.transformer.DataFormatTransformer
 
DataTypeProcessor - Class in org.apache.camel.processor.transformer
Processor applies data type conversion based on given format name.
DataTypeProcessor() - Constructor for class org.apache.camel.processor.transformer.DataTypeProcessor
 
DataTypeProcessor(String, String) - Constructor for class org.apache.camel.processor.transformer.DataTypeProcessor
 
deadLetter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
DeadLetterChannel - Class in org.apache.camel.processor.errorhandler
Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
DeadLetterChannel(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, Processor, String, boolean, boolean, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.DeadLetterChannel
Creates the dead letter channel.
deadLetterHandleNewException - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
deadLetterUri - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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_EXCHANGE_FORMATTER - Static variable in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
DEFAULT_KEY - Static variable in class org.apache.camel.processor.AbstractThrottler
 
DEFAULT_POLICY - Static variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
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
 
DefaultAnnotationBasedProcessorFactory - Class in org.apache.camel.processor
 
DefaultAnnotationBasedProcessorFactory() - Constructor for class org.apache.camel.processor.DefaultAnnotationBasedProcessorFactory
 
DefaultClaimCheckRepository - Class in org.apache.camel.processor
The default ClaimCheckRepository implementation that is an in-memory storage.
DefaultClaimCheckRepository() - Constructor for class org.apache.camel.processor.DefaultClaimCheckRepository
 
defaultCompletionMode() - Static method in enum class org.apache.camel.processor.saga.SagaCompletionMode
 
DefaultDeferServiceFactory - Class in org.apache.camel.processor
 
DefaultDeferServiceFactory() - Constructor for class org.apache.camel.processor.DefaultDeferServiceFactory
 
DefaultErrorHandler - Class in org.apache.camel.processor.errorhandler
Default error handler
DefaultErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.DefaultErrorHandler
Creates the default error handler.
DefaultExceptionPolicyStrategy - Class in org.apache.camel.processor.errorhandler
The default strategy used in Camel to resolve the ExceptionPolicyKey that should handle the thrown exception.
DefaultExceptionPolicyStrategy() - Constructor for class org.apache.camel.processor.errorhandler.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
 
DefaultInternalProcessorFactory - Class in org.apache.camel.processor
 
DefaultInternalProcessorFactory() - Constructor for class org.apache.camel.processor.DefaultInternalProcessorFactory
 
DefaultProcessorFactory - Class in org.apache.camel.processor
Default ProcessorFactory that supports using 3rd party Camel components to implement the EIP Processor.
DefaultProcessorFactory() - Constructor for class org.apache.camel.processor.DefaultProcessorFactory
 
DefaultTransformerLoader - Class in org.apache.camel.processor.transformer
Transformer loader loads known default Transformer implementations.
DefaultTransformerLoader() - Constructor for class org.apache.camel.processor.transformer.DefaultTransformerLoader
 
defensiveCopyExchangeIfNeeded(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Performs a defensive copy of the exchange if needed
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.LoopProcessor
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.WireTapProcessor
 
delay(long, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Delays the given time before continuing.
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
 
delayPattern - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
delayPattern - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
delayPattern(String) - Method in class org.apache.camel.processor.errorhandler.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
 
delimiter(String) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
Set delimiter used for joining aggregated String
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.errorhandler.RedeliveryErrorHandler.RedeliveryTask
All redelivery attempts failed so move the exchange to the dead letter queue
deliverToOnRedeliveryProcessor() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
Gives an optional configured redelivery processor a chance to process before the Exchange will be redelivered.
destination - Variable in class org.apache.camel.processor.SendProcessor
 
destinationExchangePattern - Variable in class org.apache.camel.processor.SendProcessor
 
determineIfRedeliveryIsEnabled() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
determineIfRedeliveryIsEnabled(CamelContext) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
determineRedeliveryDelay(Exchange, RedeliveryPolicy, long, int) - Method in class org.apache.camel.processor.errorhandler.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)
DisabledProcessor - Class in org.apache.camel.processor
A disabled EIP that does not do anything
DisabledProcessor() - Constructor for class org.apache.camel.processor.DisabledProcessor
 
disableRedelivery - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
disableRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Disables redelivery by setting maximum redeliveries to 0.
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
 
doAggregate(AtomicReference<Exchange>, Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result.
doAggregationComplete(String, List<Exchange>, String, Exchange, Exchange, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doAggregationRepositoryAdd(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doBuild() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doBuild() - Method in class org.apache.camel.processor.Enricher
 
doBuild() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
doBuild() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doBuild() - Method in class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
doBuild() - Method in class org.apache.camel.processor.MulticastProcessor
 
doBuild() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doBuild() - Method in class org.apache.camel.processor.Pipeline
 
doBuild() - Method in class org.apache.camel.processor.PollEnricher
 
doBuild() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doBuild() - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
doBuild() - Method in class org.apache.camel.processor.Resequencer
 
doBuild() - Method in class org.apache.camel.processor.Splitter
 
doBuild() - Method in class org.apache.camel.processor.StreamResequencer
 
doBuild() - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
 
doBuild() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doBuild() - Method in class org.apache.camel.processor.validator.ProcessorValidator
 
doBuild() - Method in class org.apache.camel.processor.WireTapProcessor
 
doBuild() - Method in class org.apache.camel.processor.WrapProcessor
 
doDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
doDone(Exchange, boolean) - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTask
 
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.
doGetProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doInit() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doInit() - Method in class org.apache.camel.processor.CatchProcessor
 
doInit() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doInit() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
doInit() - Method in class org.apache.camel.processor.Enricher
 
doInit() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
doInit() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doInit() - Method in class org.apache.camel.processor.FilterProcessor
 
doInit() - Method in class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
doInit() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doInit() - Method in class org.apache.camel.processor.MulticastProcessor
 
doInit() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doInit() - Method in class org.apache.camel.processor.Pipeline
 
doInit() - Method in class org.apache.camel.processor.PollEnricher
 
doInit() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doInit() - Method in class org.apache.camel.processor.Resequencer
 
doInit() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
doInit() - Method in class org.apache.camel.processor.SendProcessor
 
doInit() - Method in class org.apache.camel.processor.Splitter
 
doInit() - Method in class org.apache.camel.processor.StreamResequencer
 
doInit() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
doInit() - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
 
doInit() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doInit() - Method in class org.apache.camel.processor.validator.ProcessorValidator
 
doInit() - Method in class org.apache.camel.processor.WireTapProcessor
 
doInit() - Method in class org.apache.camel.processor.WrapProcessor
 
doInOptimisticLock(Exchange, String, AsyncCallback, int, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
done() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
done(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
done(Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
doProcess(Exchange, String, AsyncCallback, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MulticastProcessor
 
doProcess(Processor, Exchange) - Static method in class org.apache.camel.processor.OnCompletionProcessor
Processes the exchange by the processors
doShutdown() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doShutdown() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doShutdown() - Method in class org.apache.camel.processor.ConcurrentRequestsThrottler
 
doShutdown() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doShutdown() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
doShutdown() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
doShutdown() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doShutdown() - Method in class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
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.Pipeline
 
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.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.TotalRequestsThrottler
 
doShutdown() - Method in class org.apache.camel.processor.WireTapProcessor
 
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.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.ConcurrentRequestsThrottler
 
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.errorhandler.NoErrorHandler
 
doStart() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
doStart() - Method in class org.apache.camel.processor.EventNotifierProducer
 
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.InterceptSendToEndpointProcessor
 
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.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.Resequencer
 
doStart() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
doStart() - Method in class org.apache.camel.processor.RoutingSlip
 
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.StreamResequencer
 
doStart() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStart() - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
doStart() - Method in class org.apache.camel.processor.transformer.DataFormatTransformer
 
doStart() - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
 
doStart() - Method in class org.apache.camel.processor.TryProcessor
 
doStart() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doStart() - Method in class org.apache.camel.processor.validator.ProcessorValidator
 
doStart() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStart() - Method in class org.apache.camel.processor.WrapProcessor
 
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.Enricher
 
doStop() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
doStop() - Method in class org.apache.camel.processor.EventNotifierProducer
 
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.InterceptSendToEndpointProcessor
 
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.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.Resequencer
 
doStop() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
doStop() - Method in class org.apache.camel.processor.RoutingSlip
 
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.StreamResequencer
 
doStop() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStop() - Method in class org.apache.camel.processor.transformer.DataFormatTransformer
 
doStop() - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
 
doStop() - Method in class org.apache.camel.processor.TryProcessor
 
doStop() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doStop() - Method in class org.apache.camel.processor.validator.ProcessorValidator
 
doStop() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStop() - Method in class org.apache.camel.processor.WrapProcessor
 
doTimeoutDone(Exchange, boolean) - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTask
 
dynamicAware - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
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
 

E

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, String) - Constructor for class org.apache.camel.processor.Enricher
 
equals(Object) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
errorHandler - Variable in class org.apache.camel.processor.RoutingSlip
 
ErrorHandlerSupport - Class in org.apache.camel.processor.errorhandler
Support class for ErrorHandler implementations.
ErrorHandlerSupport() - Constructor for class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
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
 
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.
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
 
exceptionPolicies - Variable in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
exceptionPolicy - Variable in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
ExceptionPolicy - Class in org.apache.camel.processor.errorhandler
 
ExceptionPolicy(String, String, boolean, boolean, boolean, Predicate, Predicate, Predicate, Processor, Processor, String, Map<ExceptionPolicy.RedeliveryOption, String>, List<String>) - Constructor for class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
ExceptionPolicy.RedeliveryOption - Enum Class in org.apache.camel.processor.errorhandler
 
ExceptionPolicyKey - Class in org.apache.camel.processor.errorhandler
Exception policy key is a compound key for storing: route id + exception class + when => exception type.
ExceptionPolicyKey(String, Class<? extends Throwable>, Predicate) - Constructor for class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
Key for exception clause
ExceptionPolicyStrategy - Interface in org.apache.camel.processor.errorhandler
A strategy to determine which ExceptionPolicyKey should handle the thrown exception.
exchangeFormatter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
exchangeFormatterRef - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
exchangeFormatterRef - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
exchangeFormatterRef(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
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
 
executorService - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
exponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
expression - Variable in class org.apache.camel.processor.RoutingSlip
 
expression - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ExpressionResultComparator - Interface in org.apache.camel.processor.resequencer
A SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.
extendedStatistics - Variable in class org.apache.camel.processor.SendProcessor
 

F

FailOverLoadBalancer - Class in org.apache.camel.processor.loadbalancer
This FailOverLoadBalancer will failover to use next processor when an exception occurred
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
 
FatalFallbackErrorHandler - Class in org.apache.camel.processor
An ErrorHandler used as a safe fallback when processing by other error handlers such as the
invalid reference
org.apache.camel.model.OnExceptionDefinition
.
FatalFallbackErrorHandler(Processor) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
FatalFallbackErrorHandler(Processor, boolean) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
filter(ExceptionPolicyKey, Class<?>, Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy to filter the given type exception class with the thrown exception
FilterProcessor - Class in org.apache.camel.processor
The processor which implements the Message Filter EIP pattern.
FilterProcessor(CamelContext, Predicate, Processor) - Constructor for class org.apache.camel.processor.FilterProcessor
 
finallyProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
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
 
findPackages(Set<String>, ClassLoader) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
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
 
forceDiscardingOfAllGroups() - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force discardingof all groups
forceDiscardingOfAllGroups() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceDiscardingOfAllGroups() - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceDiscardingOfGroup(String) - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force discarding a specific group by its key.
forceDiscardingOfGroup(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceDiscardingOfGroup(String) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 

G

get(String) - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
get(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
getAdapter() - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
getAdapter(Class<T>) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
getAggregateController() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregateExecutorService() - Method in class org.apache.camel.processor.MulticastProcessor
 
getAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
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() - 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
 
getAggregationStrategy(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
getAndRemove(String) - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
getBackOffMultiplier() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getBatchTimeout() - Method in class org.apache.camel.processor.Resequencer
 
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.RecipientListProcessor
 
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
 
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.PausableProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.PollEnricher
 
getCamelContext() - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.SetVariableProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
getCamelContext() - Method in class org.apache.camel.processor.WireTapProcessor
 
getCapacity() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's capacity.
getCatchClauses() - Method in class org.apache.camel.processor.TryProcessor
 
getCaughtCount() - Method in class org.apache.camel.processor.CatchProcessor
Gets the total number of Exchanges that was caught (also matched the onWhen predicate).
getCaughtCount(String) - Method in class org.apache.camel.processor.CatchProcessor
Gets the number of Exchanges that was caught by the given exception class name (also matched the onWhen predicate).
getCaughtExceptionClassNames() - Method in class org.apache.camel.processor.CatchProcessor
Set of the caught exception fully qualified class names
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
getCollisionAvoidanceFactor() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getCollisionAvoidancePercent() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getComparator() - Method in class org.apache.camel.processor.SortProcessor
 
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
getCompletionInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
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.processor.aggregate.AggregateProcessor
 
getCompletionSizeExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutCheckerInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getContinuedPolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getCorrelationExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCorrelationExpression() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getCorrelationKey() - Method in exception class org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
getCounter() - Method in class org.apache.camel.processor.SendProcessor
 
getCurrentMaximumRequests() - Method in class org.apache.camel.processor.ConcurrentRequestsThrottler
Gets the current maximum request.
getCurrentMaximumRequests() - Method in interface org.apache.camel.processor.Throttler
 
getCurrentMaximumRequests() - Method in class org.apache.camel.processor.TotalRequestsThrottler
Gets the current maximum request per period value.
getCurrentSagaCoordinator(Exchange) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getDeadLetter() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Returns the dead letter that message exchanges will be sent to if the redelivery attempts fail
getDeadLetterUri() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getDefaultHandledPredicate() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getDelay() - Method in class org.apache.camel.processor.Delayer
 
getDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getDelayedCount() - Method in class org.apache.camel.processor.DelayProcessorSupport
Gets the current number of Exchanges being delayed (hold back due throttle limit hit)
getDelayPattern() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getDelayValue() - Method in class org.apache.camel.processor.Delayer
 
getDelegate() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
getDelimiter() - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
getDelimiter() - Method in class org.apache.camel.processor.RecipientList
 
getDestination() - Method in class org.apache.camel.processor.SendProcessor
 
getDiscarded() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged discarded
getDistributionWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getDynamicAware() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getEndpoint() - Method in class org.apache.camel.processor.EventNotifierProducer
 
getEndpoint() - Method in class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
getEndpoint() - Method in class org.apache.camel.processor.SendProcessor
 
getEndpoint() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
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
 
getErrorHandler() - Method in class org.apache.camel.processor.MulticastProcessor
 
getErrorHandler() - Method in class org.apache.camel.processor.RecipientList
 
getErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
 
getException() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getExceptionClass() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
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(Set<ExceptionPolicyKey>, Exchange, Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
 
getExceptionPolicy(Set<ExceptionPolicyKey>, Exchange, Throwable) - Method in interface org.apache.camel.processor.errorhandler.ExceptionPolicyStrategy
Resolves the ExceptionPolicyKey that should handle the thrown exception.
getExceptionPolicy(Exchange, Throwable) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Attempts to find the best suited ExceptionPolicy to be used for handling the given thrown exception.
getExceptions() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getExchange() - Method in exception class org.apache.camel.processor.idempotent.NoMessageIdException
The exchange which caused this failure
getExchange() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getExchange() - Method in exception class org.apache.camel.processor.resume.NoOffsetException
The exchange which caused this failure
getExchangeFormatterRef() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
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.processor.ExchangePatternProcessor
 
getExcludePattern() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getExcludePattern() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
getExecutorService() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getExistingEndpoint(CamelContext, Object) - Static method in class org.apache.camel.processor.PollEnricher
 
getExistingEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
getExistingEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.RoutingSlip
 
getExistingEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
getExpression() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getExpression() - Method in class org.apache.camel.processor.Enricher
 
getExpression() - Method in exception class 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.SetVariableProcessor
 
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
 
getExpressions() - Method in class org.apache.camel.processor.SetHeadersProcessor
 
getFailureCounter(Class<?>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
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.
getFilters() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getFinallyProcessor() - Method in class org.apache.camel.processor.TryProcessor
 
getHandledPolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getHeaderName() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getHeaderName() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getHeaderNames() - Method in class org.apache.camel.processor.SetHeadersProcessor
 
getId() - Method in class org.apache.camel.processor.AbstractThrottler
 
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.Delayer
 
getId() - Method in class org.apache.camel.processor.DisabledProcessor
 
getId() - Method in class org.apache.camel.processor.Enricher
 
getId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
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.PausableProcessor
 
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.RemoveVariableProcessor
 
getId() - Method in class org.apache.camel.processor.Resequencer
 
getId() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
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.saga.SagaProcessor
 
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.SetHeadersProcessor
 
getId() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getId() - Method in class org.apache.camel.processor.SetVariableProcessor
 
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.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
 
getIndex() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getIndex() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getInProgressCompleteExchanges() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getKey() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getKeys() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
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
 
getLastGoodIndex() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getLogExhaustedMessageBody() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Whether the option logExhaustedMessageBody has been configured or not
getLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.errorhandler.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.processor.errorhandler.RedeliveryErrorHandler
 
getLogger() - Method in class org.apache.camel.processor.LogProcessor
 
getMaximumFailoverAttempts() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getMaximumRedeliveries() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getMaximumRequestsExpression() - Method in class org.apache.camel.processor.AbstractThrottler
 
getMaximumRetries() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMaximumRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMessage() - Method in class org.apache.camel.processor.LogProcessor
 
getMessage() - Method in class org.apache.camel.processor.RollbackProcessor
 
getMessage() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getMessageFrequency() - Method in class org.apache.camel.processor.SamplingThrottler
 
getMessageIdExpression() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getMethodName() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
getMode() - Method in class org.apache.camel.processor.AbstractThrottler
 
getMode() - Method in class org.apache.camel.processor.ConcurrentRequestsThrottler
 
getMode() - Method in interface org.apache.camel.processor.Throttler
 
getMode() - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
getNodeType() - Method in class org.apache.camel.processor.DisabledProcessor
Node type that was disabled
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
getNumberOfHashGroups() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getOnExceptionOccurred() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getOnPrepare() - Method in class org.apache.camel.processor.RecipientList
 
getOnPrepare() - Method in class org.apache.camel.processor.WireTapProcessor
 
getOnRedelivery() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getOperation() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOptimisticLockRetryPolicy() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepositoryConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategyConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepositoryConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategyConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicyConfigurer
 
getOriginal() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
getOtherwise() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getOutBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getOutput() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Gets the output
getOutput() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
getOutput() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.LoopProcessor
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.WireTapProcessor
 
getPickExpression() - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
getPredicate() - Method in class org.apache.camel.processor.FilterProcessor
 
getPredicate() - Method in class org.apache.camel.processor.LoopProcessor
 
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.
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
getProducer() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getPropertyName() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getPropertyName() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getRandomNumberGenerator() - Static method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRatios() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
getRedeliveryDelay() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRedeliveryPolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getRejectedPolicy() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getRejectOld() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
getResumeStrategyConfiguration() - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryAttemptedLogInterval() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getRetryWhilePolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getRouteId() - Method in class org.apache.camel.processor.AbstractThrottler
 
getRouteId() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getRouteId() - Method in class org.apache.camel.processor.CatchProcessor
 
getRouteId() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getRouteId() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getRouteId() - Method in class org.apache.camel.processor.Delayer
 
getRouteId() - Method in class org.apache.camel.processor.DisabledProcessor
 
getRouteId() - Method in class org.apache.camel.processor.Enricher
 
getRouteId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getRouteId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
getRouteId() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
getRouteId() - Method in class org.apache.camel.processor.FilterProcessor
 
getRouteId() - Method in class org.apache.camel.processor.FinallyProcessor
 
getRouteId() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getRouteId() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getRouteId() - Method in class org.apache.camel.processor.LogProcessor
 
getRouteId() - Method in class org.apache.camel.processor.LoopProcessor
 
getRouteId() - Method in class org.apache.camel.processor.MulticastProcessor
 
getRouteId() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getRouteId() - Method in class org.apache.camel.processor.PausableProcessor
 
getRouteId() - Method in class org.apache.camel.processor.Pipeline
 
getRouteId() - Method in class org.apache.camel.processor.PollEnricher
 
getRouteId() - Method in class org.apache.camel.processor.RecipientList
 
getRouteId() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
getRouteId() - Method in class org.apache.camel.processor.Resequencer
 
getRouteId() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RollbackProcessor
 
getRouteId() - Method in class org.apache.camel.processor.RoutingSlip
 
getRouteId() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SamplingThrottler
 
getRouteId() - Method in class org.apache.camel.processor.ScriptProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SendProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SetHeadersProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SetVariableProcessor
 
getRouteId() - Method in class org.apache.camel.processor.SortProcessor
 
getRouteId() - Method in class org.apache.camel.processor.StopProcessor
 
getRouteId() - Method in class org.apache.camel.processor.StreamResequencer
 
getRouteId() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getRouteId() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getRouteId() - Method in class org.apache.camel.processor.TransformProcessor
 
getRouteId() - Method in class org.apache.camel.processor.TryProcessor
 
getRouteId() - Method in class org.apache.camel.processor.WireTapProcessor
 
getRuntimeWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getSagaService() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getSamplePeriod() - Method in class org.apache.camel.processor.SamplingThrottler
 
getSequenceSender() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the sequence sender.
getStatistics() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getStatusPropertyName() - Method in class org.apache.camel.processor.FilterProcessor
 
getStickyKey(Object) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
A strategy to create the key for the sticky load balancing map.
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.processor.aggregate.AggregateProcessor
 
getTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Returns the timeout handler that has been registered for notification.
getTimePeriodMillis() - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
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
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.ConcurrentRequestsThrottler
 
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.RemoveVariableProcessor
 
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.saga.SagaProcessor
 
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.SetHeadersProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetVariableProcessor
 
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.ThrowExceptionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
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
 
getType() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getType() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getType() - Method in class org.apache.camel.processor.transformer.TypeConverterTransformer
 
getUnits() - Method in class org.apache.camel.processor.SamplingThrottler
 
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.processor.RoutingSlip
 
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
 
getVariableName() - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
getVariableName() - Method in class org.apache.camel.processor.SetVariableProcessor
 
getVariableReceive() - Method in class org.apache.camel.processor.Enricher
 
getVariableReceive() - Method in class org.apache.camel.processor.PollEnricher
 
getVariableReceive() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getVariableReceive() - Method in class org.apache.camel.processor.SendProcessor
 
getVariableSend() - Method in class org.apache.camel.processor.Enricher
 
getVariableSend() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getVariableSend() - Method in class org.apache.camel.processor.SendProcessor
 
getWhen() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
getWrapped() - Method in class org.apache.camel.processor.WrapProcessor
 
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
 
GroupedBodyAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
GroupedBodyAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategyConfigurer
 
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
 
GroupedExchangeAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
GroupedExchangeAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategyConfigurer
 
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
 
GroupedMessageAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
GroupedMessageAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategyConfigurer
 

H

handleException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
handleException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
handleException(Exchange, AsyncCallback, Exception, boolean) - Static method in class org.apache.camel.processor.AbstractThrottler
 
handleInterrupt(Exchange, AsyncCallback, InterruptedException, boolean) - Static method in class org.apache.camel.processor.AbstractThrottler
 
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
hashCode() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
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.errorhandler.RedeliveryErrorHandler
 
hasNext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
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.PausableProcessor
 
hasNext() - Method in class org.apache.camel.processor.Pipeline
 
hasNext() - Method in class org.apache.camel.processor.Resequencer
 
hasNext() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
hasNext() - Method in class org.apache.camel.processor.StreamResequencer
 
hasNext() - Method in class org.apache.camel.processor.TryProcessor
 
hasNext(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Are the more routing slip(s)?
hasState() - Method in class org.apache.camel.processor.ContractAdvice
 
header - Variable in class org.apache.camel.processor.RoutingSlip
 
headersMapFactory - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
headersMapFactory - Variable in class org.apache.camel.processor.SendProcessor
 
higher(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next higher element in the sequence to the given element.

I

id - Variable in class org.apache.camel.processor.AbstractThrottler
 
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 - 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
 
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
 
ifNotException(Throwable, Exchange, boolean, CamelSagaCoordinator, CamelSagaCoordinator, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ifNotException(Throwable, Exchange, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ignoreInvalidEndpoint - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ignoreInvalidEndpoints - Variable in class org.apache.camel.processor.RoutingSlip
 
init(List<Class<?>>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
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.processor.errorhandler.DefaultExceptionPolicyStrategy
 
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
 
InterceptSendToEndpointCallback - Class in org.apache.camel.processor
Endpoint strategy used by intercept send to endpoint.
InterceptSendToEndpointCallback(CamelContext, Processor, Processor, String, boolean) - Constructor for class org.apache.camel.processor.InterceptSendToEndpointCallback
 
InterceptSendToEndpointProcessor - Class in org.apache.camel.processor
Processor used to interceptor and detour the routing when using the DefaultInterceptSendToEndpoint functionality.
InterceptSendToEndpointProcessor(InterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Constructor for class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
invoke(Object, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
isAggregateOnException() - Method in class org.apache.camel.processor.Enricher
 
isAggregateOnException() - Method in class org.apache.camel.processor.PollEnricher
 
isAllowDuplicates() - Method in class org.apache.camel.processor.Resequencer
 
isAllowNullNewExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowNullNewExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBiFunctionAdapter
 
isAllowNullOldExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowNullOldExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBiFunctionAdapter
 
isAllowOptimisedComponents() - Method in class org.apache.camel.processor.Enricher
 
isAllowOptimisedComponents() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isAllowRedeliveryWhileStopping() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isAsyncDelayed() - Method in class org.apache.camel.processor.AbstractThrottler
 
isAsyncDelayed() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isAsyncDelayed() - Method in interface org.apache.camel.processor.Throttler
 
isAsyncDelayedRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isAutoStartupComponents() - Method in class org.apache.camel.processor.Enricher
 
isAutoStartupComponents() - Method in class org.apache.camel.processor.PollEnricher
 
isAutoStartupComponents() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isBatchConsumer() - Method in class org.apache.camel.processor.Resequencer
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.AbstractThrottler
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isCallerRunsWhenRejected() - Method in interface org.apache.camel.processor.Throttler
 
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
 
isCopy() - Method in class org.apache.camel.processor.LoopProcessor
 
isCopy() - Method in class org.apache.camel.processor.WireTapProcessor
 
isCreateCopy() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Whether this error handler handles exhausted errors by moving the exchange to a dead letter channel.
isDeadLetterHandleNewException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isDiscardOnAggregationFailure() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isDiscardOnCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isDone(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Strategy to determine if the exchange is done so we can continue
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
 
isExponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isGroupExchanges() - Method in class org.apache.camel.processor.Resequencer
 
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
 
isLogContinued() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhausted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogHandled() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogNewException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogRetryAttempted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogRetryStackTrace() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogStackTrace() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isMarkRollbackOnly() - Method in class org.apache.camel.processor.RollbackProcessor
 
isMarkRollbackOnlyLast() - Method in class org.apache.camel.processor.RollbackProcessor
 
isOptimisticLocking() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isOptimisticLocking() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
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
 
isPreCompleted(String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Tests whether the given exchanges is pre-complete or not
isRandomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isRedeliveryAllowed() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
isRejectExecution() - Method in class org.apache.camel.processor.AbstractThrottler
 
isRejectExecution() - Method in interface org.apache.camel.processor.Throttler
 
isRejectOld() - Method in class org.apache.camel.processor.StreamResequencer
 
isRemoveOnFailure() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isReverse() - Method in class org.apache.camel.processor.Resequencer
 
isRoundRobin() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRunAllowed() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
isRunAllowed() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
isShutdownExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
isShutdownOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isShutdownTimeoutCheckerExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isSingleton() - Method in class org.apache.camel.processor.EventNotifierProducer
 
isSingleton() - Method in class org.apache.camel.processor.InterceptSendToEndpointProcessor
 
isSingleton() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
isSkipDuplicate() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isStatisticsEnabled() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Whether statistics is enabled.
isSticky() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
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
 
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.
isStreaming() - Method in class org.apache.camel.processor.MulticastProcessor
Is the multicast processor working in streaming mode?
isStreaming() - Method in class org.apache.camel.processor.RecipientList
 
isSynchronous() - Method in class org.apache.camel.processor.MulticastProcessor
 
isSynchronous() - Method in class org.apache.camel.processor.RecipientList
 
isUseCollisionAvoidance() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isUseExponentialBackOff() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isUseOriginalBodyPolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isUseOriginalInBody() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
isUseOriginalInMessage() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
isUseOriginalMessagePolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isValid(E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if the o1 can be used in this comparator.
isValid(Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 

L

load(TransformerRegistry) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
load(TransformerRegistry) - Method in class org.apache.camel.processor.transformer.DefaultTransformerLoader
 
LoadBalancer - Interface in org.apache.camel.processor.loadbalancer
A strategy for load balancing across a number of Processor instances
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
 
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
 
logContinued - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logContinued - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhausted - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logExhausted - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhausted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors
logExhaustedMessageBody - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logExhaustedMessageBody - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors including message body (requires message history to be enabled)
logExhaustedMessageHistory - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logExhaustedMessageHistory - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors including message history
logger - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
logHandled - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logHandled - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logHandled(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log errors even if its handled
logNewException - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logNewException - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logNewException(boolean) - Method in class org.apache.camel.processor.errorhandler.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(String, CamelLogger, MaskingFormatter, Set<LogListener>) - Constructor for class org.apache.camel.processor.LogProcessor
 
LogProcessor(Expression, CamelLogger, MaskingFormatter, Set<LogListener>) - Constructor for class org.apache.camel.processor.LogProcessor
 
logRetryAttempted - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logRetryAttempted - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logRetryAttempted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log retry attempts
logRetryStackTrace - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logRetryStackTrace - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logRetryStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log stacktrace for failed redelivery attempts
logStackTrace - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
logStackTrace - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log stacktrace for failed messages.
LoopProcessor - Class in org.apache.camel.processor
The processor which sends messages in a loop.
LoopProcessor(CamelContext, Processor, Expression, Predicate, boolean, 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.

M

MANDATORY - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
A saga must be already present.
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
 
MANUAL - Enum constant in enum class org.apache.camel.processor.saga.SagaCompletionMode
Complete the saga explicitly using the "saga:complete" endpoint.
matches(Exchange) - Method in class org.apache.camel.processor.FilterProcessor
 
matchesWhen(Exchange) - Method in class org.apache.camel.processor.CatchProcessor
Strategy method for matching the exception type with the current exchange.
matchesWhen(ExceptionPolicyKey, Exchange) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy method for matching the exception type with the current exchange.
matchPattern(String, String) - Method in class org.apache.camel.processor.InterceptSendToEndpointCallback
Does the uri match the pattern.
maximumRedeliveries - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
maximumRedeliveries - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
maximumRedeliveries(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered
maximumRedeliveryDelay - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
maximumRedeliveryDelay - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum redelivery delay if using exponential back off.
maximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maxRequestsExpression - Variable in class org.apache.camel.processor.AbstractThrottler
 
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
 
MemoryAggregationRepositoryConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
MemoryAggregationRepositoryConfigurer() - Constructor for class org.apache.camel.processor.aggregate.MemoryAggregationRepositoryConfigurer
 
MessageRejectedException - Exception Class in org.apache.camel.processor.resequencer
An exception thrown if message is rejected by the resequencer
MessageRejectedException(String) - Constructor for exception class org.apache.camel.processor.resequencer.MessageRejectedException
 
META_INF_SERVICES - Static variable in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
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, Route, Collection<Processor>) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Route, Collection<Processor>, AggregationStrategy) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Route, Collection<Processor>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor.MulticastReactiveTask - Class in org.apache.camel.processor
Sub task processed reactive via the ReactiveExecutor.
MulticastProcessor.MulticastTask - Class in org.apache.camel.processor
 
MulticastProcessor.MulticastTransactedTask - Class in org.apache.camel.processor
Transacted sub task processed synchronously using Processor.process(Exchange) with the same thread in a while loop control flow.
MulticastReactiveTask(Exchange, Iterable<ProcessorExchangePair>, AsyncCallback, int) - Constructor for class org.apache.camel.processor.MulticastProcessor.MulticastReactiveTask
 
MulticastTransactedTask(Exchange, Iterable<ProcessorExchangePair>, AsyncCallback, int) - Constructor for class org.apache.camel.processor.MulticastProcessor.MulticastTransactedTask
 

N

NEVER - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
The current block must never be invoked within a saga.
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
 
newInstance(CamelContext, List<Processor>) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(CamelContext, List<Processor>, String) - Static method in class org.apache.camel.processor.StepProcessor
 
newInstance(CamelContext, Processor...) - Static method in class org.apache.camel.processor.Pipeline
 
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.
newPipeline(CamelContext, Collection<Processor>) - Method in class org.apache.camel.processor.RecipientList
 
newRoutingSlipProcessorForErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
Creates the embedded processor to use when wrapping this routing slip in an error handler.
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.errorhandler.RedeliveryErrorHandler
 
next() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
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.PausableProcessor
 
next() - Method in class org.apache.camel.processor.Pipeline
 
next() - Method in class org.apache.camel.processor.Resequencer
 
next() - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
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
 
next(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Returns the next routing slip(s).
NoErrorHandler - Class in org.apache.camel.processor.errorhandler
 
NoErrorHandler(Processor) - Constructor for class org.apache.camel.processor.errorhandler.NoErrorHandler
 
NoMessageIdException - Exception Class 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 class org.apache.camel.processor.idempotent.NoMessageIdException
 
NoOffsetException - Exception Class in org.apache.camel.processor.resume
An exception thrown if no camel offset header could be found on the message.
NoOffsetException(Exchange) - Constructor for exception class org.apache.camel.processor.resume.NoOffsetException
 
NOT_SUPPORTED - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
If a saga already exists, it is suspended and resumed when the current block completes.
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
 

O

onAggregation(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onComplete(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onComplete(Exchange) - Method in class org.apache.camel.processor.resume.ResumableCompletion
 
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
onCompletion(String, Exchange, Exchange, boolean, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
onCompletion(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
OnCompletionProcessor - Class in org.apache.camel.processor
Processor implementing onCompletion.
OnCompletionProcessor(CamelContext, Processor, ExecutorService, boolean, boolean, boolean, Predicate, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.OnCompletionProcessor
 
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
onExceptionOccurred() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
Gives an optional configured OnExceptionOccurred processor a chance to process just after an exception was thrown while processing the Exchange.
onExceptionOccurred() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
Gives an optional configured OnExceptionOccurred processor a chance to process just after an exception was thrown while processing the Exchange.
onExceptionProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
onFailure(Exchange) - Method in class org.apache.camel.processor.resume.ResumableCompletion
 
onHandledFailure(Exception) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
onOptimisticLockFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
onOptimisticLockingFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onPrepare - Variable in class org.apache.camel.processor.MulticastProcessor
 
onPrepareProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
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
 
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
 
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.errorhandler - package org.apache.camel.processor.errorhandler
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.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.resume - package org.apache.camel.processor.resume
 
org.apache.camel.processor.saga - package org.apache.camel.processor.saga
Saga EIP implementation.
org.apache.camel.processor.transformer - package org.apache.camel.processor.transformer
Transformer implementation classes.
org.apache.camel.processor.validator - package org.apache.camel.processor.validator
Validator implementation classes.
output - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
outputAsync - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 

P

pattern - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
pattern - Variable in class org.apache.camel.processor.SendProcessor
 
PausableProcessor - Class in org.apache.camel.processor
 
PausableProcessor(Processor) - Constructor for class org.apache.camel.processor.PausableProcessor
 
pick(Expression) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
Set an expression to extract the element to be aggregated from the incoming Exchange.
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
 
PipelineHelper - Class in org.apache.camel.processor
Helper for processing Exchange in a pipeline.
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(String, long) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
PollEnricher(Expression, String, long) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
PooledExchangeTask - Interface in org.apache.camel.processor
A task that EIPs and internal routing engine uses to store state when processing an Exchange.
PooledExchangeTaskFactory - Interface in org.apache.camel.processor
Factory to create PooledExchangeTask.
PooledTaskFactory - Class in org.apache.camel.processor
 
PooledTaskFactory() - Constructor for class org.apache.camel.processor.PooledTaskFactory
 
PooledTaskFactory(Object) - Constructor for class org.apache.camel.processor.PooledTaskFactory
 
pop() - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
postProcess(Exchange) - Method in class org.apache.camel.processor.Resequencer
 
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
 
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.
predecessor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
prepare(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
prepare(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
prepare(Exchange, AsyncCallback) - Method in interface org.apache.camel.processor.PooledExchangeTask
Prepares the task for the given exchange and its callback
prepareExchange(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
Prepares the Exchange to send as onCompletion.
prepareExchange(Exchange, int) - Method in class org.apache.camel.processor.LoopProcessor
Prepares the exchange for the next iteration
prepareExchangeAfterFailure(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
prepareExchangeAfterFailure(Exchange, boolean, boolean, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
prepareExchangeForContinue(Exchange, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
prepareExchangeForFailover(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Prepares the exchange for failover
prepareExchangeForRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
prepareExchangeForRoutingSlip(Exchange, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
prepareRecipient(Exchange, Object) - Static method in class org.apache.camel.processor.PollEnricher
 
prepareRecipient(Exchange, Object) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
prepareRecipient(Exchange, Object) - Static method in class org.apache.camel.processor.RoutingSlip
 
prepareRecipient(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
prepareSharedUnitOfWork(Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Prepares the exchange for participating 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.errorhandler.RedeliveryErrorHandler
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.LoopProcessor
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.WireTapProcessor
 
preparingShutdown - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.transformer.DataTypeProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
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, AsyncCallback) - Method in class org.apache.camel.processor.ConcurrentRequestsThrottler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DisabledProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Enricher
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Process the exchange using redelivery error handling.
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.InterceptSendToEndpointProcessor
 
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.PausableProcessor
 
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, 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.RemoveVariableProcessor
 
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.resume.ResumableProcessor
 
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.SetHeadersProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetVariableProcessor
 
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.ThrowExceptionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
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.processor.errorhandler.NoErrorHandler
 
processAsync(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
processAsynchronously(Exchange, AsyncCallback, ConcurrentRequestsThrottler.ThrottlingState) - Method in class org.apache.camel.processor.ConcurrentRequestsThrottler
Delegate blocking to an asyncExecutor.
processAsynchronously(Exchange, AsyncCallback, TotalRequestsThrottler.ThrottlingState) - Method in class org.apache.camel.processor.TotalRequestsThrottler
Delegate blocking on the DelayQueue to an asyncExecutor.
processDelay(Exchange, AsyncCallback, long) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
processExchange(Endpoint, Exchange, Exchange, AsyncCallback, RoutingSlip.RoutingSlipIterator, boolean) - Method in class org.apache.camel.processor.RoutingSlip
 
processExchange(Exchange) - Method in class org.apache.camel.processor.Resequencer
Strategy Method to process an exchange in the batch.
processorExchangeFactory - Variable in class org.apache.camel.processor.MulticastProcessor
 
ProcessorExchangePair - Interface in org.apache.camel.processor
Exchange pair to be executed by MulticastProcessor.
ProcessorTransformer - Class in org.apache.camel.processor.transformer
A Transformer implementation which leverages Processor to perform transformation.
ProcessorTransformer() - Constructor for class org.apache.camel.processor.transformer.ProcessorTransformer
 
ProcessorTransformer(CamelContext) - Constructor for class org.apache.camel.processor.transformer.ProcessorTransformer
 
ProcessorValidator - Class in org.apache.camel.processor.validator
A Validator implementation which leverages Processor to perform validation.
ProcessorValidator(CamelContext) - Constructor for class org.apache.camel.processor.validator.ProcessorValidator
 
producer - Variable in class org.apache.camel.processor.SendProcessor
 
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
 
propagateException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagation(SagaPropagation) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
PROPERTY_EXCHANGE_QUEUED_TIMESTAMP - Static variable in class org.apache.camel.processor.AbstractThrottler
 
PROPERTY_EXCHANGE_STATE - Static variable in class org.apache.camel.processor.AbstractThrottler
 
PrototypeTaskFactory - Class in org.apache.camel.processor
 
PrototypeTaskFactory() - Constructor for class org.apache.camel.processor.PrototypeTaskFactory
 
push(Exchange) - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 

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
 

R

randomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the random load balancing policy
RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
randomNumberGenerator - Static variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
ratios - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
reactiveExecutor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
reactiveExecutor - Variable in class org.apache.camel.processor.TryProcessor
 
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
 
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, Route, Expression, String, ProducerCache, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
redeliver() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
redeliveryDelay - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
redeliveryDelay - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
redeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
redeliveryEnabled - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryErrorHandler - Class in org.apache.camel.processor.errorhandler
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, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryErrorHandler.RedeliveryTask - Class in org.apache.camel.processor.errorhandler
Task to perform calling the processor and handling redelivery if it fails (more advanced than ProcessTask)
RedeliveryErrorHandler.SimpleTask - Class in org.apache.camel.processor.errorhandler
Simple task to perform calling the processor with no redelivery support
redeliveryPolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryPolicy - Class in org.apache.camel.processor.errorhandler
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.errorhandler.RedeliveryPolicy
 
RedeliveryPolicyConfigurer - Class in org.apache.camel.processor.errorhandler
Generated by camel build tools - do NOT edit this file!
RedeliveryPolicyConfigurer() - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryPolicyConfigurer
 
redeliveryProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
redeliverySleepCounter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryTask() - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
registerEndpoint(String, Endpoint) - Method in class org.apache.camel.processor.InterceptSendToEndpointCallback
 
rejectExecution - Variable in class org.apache.camel.processor.AbstractThrottler
 
release(PooledExchangeTask) - Method in interface org.apache.camel.processor.PooledExchangeTaskFactory
Releases the task after its done being used
release(PooledExchangeTask) - Method in class org.apache.camel.processor.PooledTaskFactory
 
release(PooledExchangeTask) - Method in class org.apache.camel.processor.PrototypeTaskFactory
 
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.
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
 
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
 
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
 
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
 
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
 
RemoveVariableProcessor - Class in org.apache.camel.processor
A processor which removes the variable
RemoveVariableProcessor(Expression) - Constructor for class org.apache.camel.processor.RemoveVariableProcessor
 
REQUIRED - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
Join the existing saga or create a new one if it does not exist.
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
 
REQUIRES_NEW - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
Always create a new saga.
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
 
Resequencer - Class in org.apache.camel.processor
An implementation of the Resequencer which can reorder messages within a batch.
Resequencer(CamelContext, Processor, Set<Exchange>, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
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
 
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 interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Reset the counters
reset() - Method in class org.apache.camel.processor.CatchProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.ChoiceProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
reset() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
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 interface org.apache.camel.processor.PooledExchangeTask
Resets the task after its done and can be reused for another exchange.
reset() - Method in class org.apache.camel.processor.SendProcessor
 
resetDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Resets the duplicate message counter to 0L.
resolve(CamelContext, String) - Method in class org.apache.camel.processor.SendDynamicAwareResolver
 
resolveEndpoint(CamelContext, Object, boolean) - Static method in class org.apache.camel.processor.PollEnricher
 
resolveEndpoint(Exchange, Object, boolean) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
resolveEndpoint(Exchange, Object, boolean) - Method in class org.apache.camel.processor.RoutingSlip
 
resolveEndpoint(Exchange, Object, boolean) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveExchangePattern(Object) - Method in class org.apache.camel.processor.RecipientListProcessor
 
resolveScheme(Exchange, String) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveUri(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
RESOURCE_PATH - Static variable in class org.apache.camel.processor.DefaultProcessorFactory
 
RESOURCE_PATH - Static variable in class org.apache.camel.processor.SendDynamicAwareResolver
 
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, boolean, Map<String, String>, Map<String, String>, boolean, Set<String>, Set<String>) - Constructor for class org.apache.camel.processor.RestBindingAdvice
 
restoreTimeoutMapFromAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Restores the timeout map with timeout values from the aggregation repository.
ResumableCompletion - Class in org.apache.camel.processor.resume
 
ResumableCompletion(ResumeStrategy, LoggingLevel, boolean) - Constructor for class org.apache.camel.processor.resume.ResumableCompletion
 
ResumableProcessor - Class in org.apache.camel.processor.resume
Resume EIP
ResumableProcessor(ResumeStrategy, Processor, LoggingLevel, boolean) - Constructor for class org.apache.camel.processor.resume.ResumableProcessor
 
retriesExhaustedLogLevel - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
retriesExhaustedLogLevel - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
retryAttemptedLogInterval - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
retryAttemptedLogInterval - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the interval to log retry attempts
retryAttemptedLogLevel - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
retryAttemptedLogLevel - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
retryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
retryWhilePolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
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
 
routeId - Variable in class org.apache.camel.processor.AbstractThrottler
 
routeId - Variable in class org.apache.camel.processor.RoutingSlip
 
routeId - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
routeId - Variable in class org.apache.camel.processor.SendProcessor
 
routeId - Variable in class org.apache.camel.processor.TryProcessor
 
RoutePipeline - Class in org.apache.camel.processor
Pipeline used as starting point for Route.
RoutePipeline(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.RoutePipeline
 
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.
run() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
Processing and redelivery logic.
run() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
Processing logic.
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.MulticastReactiveTask
 
run() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTask
 
run() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTransactedTask
 
run() - Method in class org.apache.camel.processor.resequencer.Timeout
Notifies the timeout handler about the scheduled timeout.
runtimeRatioSum - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 

S

SagaCompletionMode - Enum Class in org.apache.camel.processor.saga
Enumerates all saga completion modes.
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 Class in org.apache.camel.processor.saga
Enumerates all saga propagation modes.
sagaService - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
sagaService(CamelSagaService) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
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
 
schedule() - Method in class org.apache.camel.processor.resequencer.Timeout
Schedules this timeout task.
schedule(Runnable) - Method in class org.apache.camel.processor.MulticastProcessor
 
schedule(Executor, Runnable, long, TimeUnit) - Method in class org.apache.camel.processor.MulticastProcessor
 
scheme - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
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
 
SendDynamicAwareResolver - Class in org.apache.camel.processor
 
SendDynamicAwareResolver() - Constructor for class org.apache.camel.processor.SendDynamicAwareResolver
 
SendDynamicProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to a dynamic endpoint destination.
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.
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
 
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.
setAdapter(ResumeAdapter) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
setAggregateController(AggregateController) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregateExecutorService(ExecutorService) - Method in class org.apache.camel.processor.MulticastProcessor
 
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.processor.aggregate.AggregateProcessor
 
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
 
setAggregationStrategyOnExchange(Exchange, AggregationStrategy) - Method in class org.apache.camel.processor.MulticastProcessor
Sets the given AggregationStrategy on the Exchange.
setAllowDuplicates(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setAllowNullNewExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowNullNewExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBiFunctionAdapter
 
setAllowNullOldExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowNullOldExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBiFunctionAdapter
 
setAllowOptimisedComponents(boolean) - Method in class org.apache.camel.processor.Enricher
 
setAllowOptimisedComponents(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setAllowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.AbstractThrottler
 
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether asynchronous delayed redelivery is allowed.
setAutoStartupComponents(boolean) - Method in class org.apache.camel.processor.Enricher
 
setAutoStartupComponents(boolean) - Method in class org.apache.camel.processor.PollEnricher
 
setAutoStartupComponents(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setBackOffMultiplier(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the multiplier used to increase the delay between redeliveries if RedeliveryPolicy.setUseExponentialBackOff(boolean) is enabled
setBatchConsumer(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the in batch size.
setBatchTimeout(long) - Method in class org.apache.camel.processor.Resequencer
 
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
 
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.RecipientListProcessor
 
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.processor.AbstractThrottler
 
setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
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.PausableProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.PollEnricher
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.SetVariableProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.WireTapProcessor
 
setCapacity(int) - Method in class org.apache.camel.processor.StreamResequencer
 
setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the factor used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the percentage used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCompleteAllOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionFromBatchConsumer(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionOnNewCorrelationGroup(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.Resequencer
 
setCompletionSize(int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionSizeExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeout(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutCheckerInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCorrelationExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCurrentSagaCoordinator(Exchange, CamelSagaCoordinator) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
setDataFormat(DataFormat) - Method in class org.apache.camel.processor.transformer.DataFormatTransformer
Set DataFormat.
setDelay(Expression) - Method in class org.apache.camel.processor.Delayer
 
setDelayPattern(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets an optional delay pattern to use instead of fixed delay.
setDelimiter(String) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
setDelimiter(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setDeliveryAttemptInterval(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setDiscardOnAggregationFailure(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setDiscardOnCompletionTimeout(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setEagerCheckCompletion(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setErrorHandler(AsyncProcessor) - Method in class org.apache.camel.processor.RoutingSlip
 
setErrorHandler(Processor) - Method in class org.apache.camel.processor.MulticastProcessor
 
setErrorHandler(Processor) - Method in class org.apache.camel.processor.RecipientList
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.Resequencer
 
setExchangeFormatterRef(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.RecipientList
 
setExponentialBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
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.
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setForceCompletionOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setFromType(String) - Method in class org.apache.camel.processor.transformer.DataTypeProcessor
 
setGroupExchanges(boolean) - Method in class org.apache.camel.processor.Resequencer
 
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
 
SetHeadersProcessor - Class in org.apache.camel.processor
A processor which sets multipe headers on the IN or OUT message with an Expression
SetHeadersProcessor(List<Expression>, List<Expression>) - Constructor for class org.apache.camel.processor.SetHeadersProcessor
 
setId(String) - Method in class org.apache.camel.processor.AbstractThrottler
 
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.Delayer
 
setId(String) - Method in class org.apache.camel.processor.DisabledProcessor
 
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.PausableProcessor
 
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.RemoveVariableProcessor
 
setId(String) - Method in class org.apache.camel.processor.Resequencer
 
setId(String) - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
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.saga.SagaProcessor
 
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.SetHeadersProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetVariableProcessor
 
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.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
 
setIgnoreInvalidCorrelationKeys(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
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.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.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.
setIgnoreMissingDataType(boolean) - Method in class org.apache.camel.processor.transformer.DataTypeProcessor
 
setKey(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setLogContinued(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged even if its continued
setLogExhausted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted exceptions should be logged or not
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted message body/headers should be logged with message history included (requires logExhaustedMessageHistory to be enabled).
setLogExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted exceptions should be logged with message history included.
setLogHandled(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged even if its handled
setLogNewException(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged when a new exception occurred during handling a previous exception
setLogRetryAttempted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether retry attempts should be logged or not
setLogRetryStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether stack traces should be logged or not
setLogStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether stack traces should be logged or not
setMarkRollbackOnly(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMarkRollbackOnlyLast(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMaximumFailoverAttempts(int) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered.
setMaximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum redelivery delay.
setMaximumRequestsExpression(Expression) - Method in class org.apache.camel.processor.AbstractThrottler
Sets the maximum number of concurrent requests.
setMaximumRequestsExpression(Expression) - Method in interface org.apache.camel.processor.Throttler
 
setMaximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMaximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMethodName(String) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setNodeType(String) - Method in class org.apache.camel.processor.DisabledProcessor
 
setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.RecipientList
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
setOperation(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setOptimisticLocking(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLocking(boolean) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
setOptimisticLockingExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOutBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the out batch size.
setPackageName(String) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
setParallelAggregate(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setPattern(ExchangePattern) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setPickExpression(Expression) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
setProcessor(Processor) - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
Set processor to use
setProcessor(Processor) - Method in class org.apache.camel.processor.validator.ProcessorValidator
Set processor to use
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
 
setRandomBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
setRejectExecution(boolean) - Method in class org.apache.camel.processor.AbstractThrottler
 
setRejectOld(Boolean) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
setRejectOld(Boolean) - Method in class org.apache.camel.processor.StreamResequencer
 
setResumeStrategyConfiguration(ResumeStrategyConfiguration) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
setRetryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the interval to log retry attempts
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
setRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setReverse(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setRoundRobin(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setRouteId(String) - Method in class org.apache.camel.processor.AbstractThrottler
 
setRouteId(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.CatchProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.ChoiceProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.Delayer
 
setRouteId(String) - Method in class org.apache.camel.processor.DisabledProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.Enricher
 
setRouteId(String) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.FilterProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.FinallyProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
setRouteId(String) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
setRouteId(String) - Method in class org.apache.camel.processor.LogProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.LoopProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.MulticastProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.PausableProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.Pipeline
 
setRouteId(String) - Method in class org.apache.camel.processor.PollEnricher
 
setRouteId(String) - Method in class org.apache.camel.processor.RecipientList
 
setRouteId(String) - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RemoveVariableProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.Resequencer
 
setRouteId(String) - Method in class org.apache.camel.processor.resume.ResumableProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RollbackProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setRouteId(String) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SamplingThrottler
 
setRouteId(String) - Method in class org.apache.camel.processor.ScriptProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SendProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SetBodyProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SetHeadersProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SetVariableProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.SortProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.StopProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.StreamResequencer
 
setRouteId(String) - Method in class org.apache.camel.processor.ThreadsProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.TransformProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.TryProcessor
 
setRouteId(String) - Method in class org.apache.camel.processor.WireTapProcessor
 
setSequenceSender(SequenceSender<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets the sequence sender.
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.Enricher
 
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShutdownExecutorService(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShutdownOptimisticLockingExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setShutdownTimeoutCheckerExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Sets whether statistics is enabled.
setStatusPropertyName(String) - Method in class org.apache.camel.processor.FilterProcessor
 
setSticky(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setStopOnException(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStreaming(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setSynchronous(boolean) - Method in class org.apache.camel.processor.MulticastProcessor
 
setSynchronous(boolean) - Method in class org.apache.camel.processor.RecipientList
 
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.processor.aggregate.AggregateProcessor
 
setTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
Sets a timeout handler for receiving timeout notifications.
setTimePeriodMillis(long) - Method in class org.apache.camel.processor.TotalRequestsThrottler
Sets the time period during which the maximum number of requests apply
setToEndpoint(Exchange, Endpoint) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
setToEndpoint(Exchange, Processor) - Static method in class org.apache.camel.processor.MulticastProcessor
 
setToType(String) - Method in class org.apache.camel.processor.transformer.DataTypeProcessor
 
setTransformer(Transformer) - Method in class org.apache.camel.processor.transformer.DataTypeProcessor
 
setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables/disables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables/disables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
SetVariableProcessor - Class in org.apache.camel.processor
A processor which sets the variable with an Expression
SetVariableProcessor(Expression, Expression) - Constructor for class org.apache.camel.processor.SetVariableProcessor
 
setVariableReceive(String) - Method in class org.apache.camel.processor.Enricher
 
setVariableReceive(String) - Method in class org.apache.camel.processor.PollEnricher
 
setVariableReceive(String) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setVariableReceive(String) - Method in class org.apache.camel.processor.SendProcessor
 
setVariableSend(String) - Method in class org.apache.camel.processor.Enricher
 
setVariableSend(String) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setVariableSend(String) - Method in class org.apache.camel.processor.SendProcessor
 
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?
shouldRedeliver(Exchange, int, Predicate) - Method in class org.apache.camel.processor.errorhandler.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
 
shutdownAsyncExecutor - Variable in class org.apache.camel.processor.AbstractThrottler
 
shutdownStrategy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
simpleTask - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
SimpleTask() - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
size() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the number of elements currently maintained by this resequencer.
sleep() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
Method for sleeping during redelivery attempts.
sleep(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sleeps for the given delay
sleep(long, int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Calculates the new redelivery delay based on the last one and then sleeps for the necessary amount of time.
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
 
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, Route, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
Splitter(CamelContext, Route, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, String) - Constructor for class org.apache.camel.processor.Splitter
 
start() - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
start() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
start() - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
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
 
step - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
step(CamelSagaStep) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
StepProcessor - Class in org.apache.camel.processor
 
StepProcessor(CamelContext, Collection<Processor>, String) - Constructor for class org.apache.camel.processor.StepProcessor
 
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
 
stop() - Method in class org.apache.camel.processor.DefaultClaimCheckRepository
 
stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Stops this resequencer (i.e.
stop() - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
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
 
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.
StringAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate result of pick expression into a single combined Exchange holding all the aggregated bodies in a String as the message body.
StringAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
StringAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
StringAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.StringAggregationStrategyConfigurer
 
StringDataTypeTransformer - Class in org.apache.camel.processor.transformer
Generic String data type converts Exchange payload to String representation using the Camel message body converter mechanism.
StringDataTypeTransformer() - Constructor for class org.apache.camel.processor.transformer.StringDataTypeTransformer
 
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.
successor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
SUPPORTS - Enum constant in enum class org.apache.camel.processor.saga.SagaPropagation
If a saga already exists, then join it.
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
 
supportTransacted() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Whether this error handler supports transacted exchanges or not.
supportTransacted() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
supportTransacted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
SYNC - Enum constant in enum class org.apache.camel.processor.AbstractThrottler.State
 

T

taskFactory - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
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
 
Throttler - Interface in org.apache.camel.processor
 
ThrottlerRejectedExecutionException - Exception Class in org.apache.camel.processor
 
ThrottlerRejectedExecutionException(String) - Constructor for exception class org.apache.camel.processor.ThrottlerRejectedExecutionException
 
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
 
timeout() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastTask
 
timeout(Exchange, int, int, long) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
timeout(Timeout) - Method in interface org.apache.camel.processor.resequencer.TimeoutHandler
Handles a timeout notification.
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.
TimeoutHandler - Interface in org.apache.camel.processor.resequencer
Implemented by classes that handle timeout notifications.
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
 
toString() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
toString() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
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.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.ConcurrentRequestsThrottler
 
toString() - Method in class org.apache.camel.processor.Delayer
 
toString() - Method in class org.apache.camel.processor.DisabledProcessor
 
toString() - Method in class org.apache.camel.processor.Enricher
 
toString() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
toString() - Method in class org.apache.camel.processor.errorhandler.DefaultErrorHandler
 
toString() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
toString() - Method in class org.apache.camel.processor.errorhandler.NoErrorHandler
 
toString() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryTask
 
toString() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.SimpleTask
 
toString() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
toString() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
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.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.MulticastTask
 
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.PooledTaskFactory
 
toString() - Method in class org.apache.camel.processor.PrototypeTaskFactory
 
toString() - Method in class org.apache.camel.processor.RecipientList
 
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.RemoveVariableProcessor
 
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.SetHeadersProcessor
 
toString() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
toString() - Method in class org.apache.camel.processor.SetVariableProcessor
 
toString() - Method in class org.apache.camel.processor.SortProcessor
 
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.ThrowExceptionProcessor
 
toString() - Method in class org.apache.camel.processor.TotalRequestsThrottler
 
toString() - Method in class org.apache.camel.processor.transformer.DataFormatTransformer
 
toString() - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
 
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.validator.ProcessorValidator
 
toString() - Method in class org.apache.camel.processor.WireTapProcessor
 
toString() - Method in class org.apache.camel.processor.WrapProcessor
 
TotalRequestsThrottler - 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.
TotalRequestsThrottler(CamelContext, Expression, long, ScheduledExecutorService, boolean, boolean, Expression) - Constructor for class org.apache.camel.processor.TotalRequestsThrottler
 
traceLabelToString - Variable in class org.apache.camel.processor.SendProcessor
 
trackTimeout(String, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.AnnotationTransformerLoader
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.ByteArrayDataTypeTransformer
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.DataFormatTransformer
Perform data transformation with specified from/to type using DataFormat.
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.DefaultTransformerLoader
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.ProcessorTransformer
Perform data transformation with specified from/to type using Processor.
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.StringDataTypeTransformer
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.processor.transformer.TypeConverterTransformer
 
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
 
TransientResumeStrategy - Class in org.apache.camel.processor.resume
A resume strategy that keeps all the resume strategy information in memory.
TransientResumeStrategy(ResumeAdapter) - Constructor for class org.apache.camel.processor.resume.TransientResumeStrategy
 
tryProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
TryProcessor - Class in org.apache.camel.processor
Implements try/catch/finally type processing
TryProcessor(CamelContext, Processor, List<Processor>, Processor) - Constructor for class org.apache.camel.processor.TryProcessor
 
TypeConverterTransformer - Class in org.apache.camel.processor.transformer
Data type converter receives a name and a target type in order to use traditional exchange body conversion mechanisms in order to transform the message body to a given type.
TypeConverterTransformer(Class<?>) - Constructor for class org.apache.camel.processor.transformer.TypeConverterTransformer
 
TypeConverterTransformer(DataType) - Constructor for class org.apache.camel.processor.transformer.TypeConverterTransformer
 

U

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.
updateLastOffset(OffsetKey<?>, Offset<?>) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
updateLastOffset(OffsetKey<?>, Offset<?>, ResumeStrategy.UpdateCallBack) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
updateLastOffset(T) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
updateLastOffset(T, ResumeStrategy.UpdateCallBack) - Method in class org.apache.camel.processor.resume.TransientResumeStrategy
 
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 - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
uriDelimiter - Variable in class org.apache.camel.processor.RoutingSlip
 
useCollisionAvoidance - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
useCollisionAvoidance - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
useCollisionAvoidance() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
useExponentialBackOff - Enum constant in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
 
useExponentialBackOff - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
useExponentialBackOff() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
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
 
UseLatestAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
UseLatestAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.UseLatestAggregationStrategyConfigurer
 
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
 
UseOriginalAggregationStrategyConfigurer - Class in org.apache.camel.processor.aggregate
Generated by camel build tools - do NOT edit this file!
UseOriginalAggregationStrategyConfigurer() - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategyConfigurer
 
useOriginalBodyPolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
useOriginalMessagePolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 

V

validate(Message, DataType) - Method in class org.apache.camel.processor.validator.ProcessorValidator
Perform content validation with specified type using Processor.
valueOf(String) - Static method in enum class org.apache.camel.processor.AbstractThrottler.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.camel.processor.saga.SagaCompletionMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.camel.processor.saga.SagaPropagation
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.apache.camel.processor.AbstractThrottler.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.camel.processor.saga.SagaCompletionMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.camel.processor.saga.SagaPropagation
Returns an array containing the constants of this enum class, in the order they are declared.
variableReceive - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
variableReceive - Variable in class org.apache.camel.processor.SendProcessor
 
variableSend - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
variableSend - Variable in class org.apache.camel.processor.SendProcessor
 

W

WeightedLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
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
 
WireTapProcessor - Class in org.apache.camel.processor
Processor for wire tapping exchanges to an endpoint destination.
WireTapProcessor(SendDynamicProcessor, Processor, String, ExchangePattern, boolean, ExecutorService, boolean, boolean) - Constructor for class org.apache.camel.processor.WireTapProcessor
 
wrapInErrorHandler(Route, Exchange, Processor) - Method in class org.apache.camel.processor.MulticastProcessor
 
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
 
A B C D E F G H I L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form