All Classes
-
All Classes Interface Summary Class Summary Enum Summary Exception Summary Class Description AbstractListAggregationStrategy<V> Aggregate all exchanges into aListof values defined by theAbstractListAggregationStrategy.getValue(Exchange)call.AggregateController A controller which allows controlling aAggregateProcessorfrom an external source, such as Java API or JMX.AggregateProcessor An implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind ofAggregationStrategy(by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.AggregateProcessorStatistics Various statistics of the aggregatorAggregationStrategyBeanAdapter AnAggregationStrategythat adapts to a POJO.AggregationStrategyBeanInfo Class information about the POJO method to call when using theAggregationStrategyBeanAdapter.AggregationStrategyBiFunctionAdapter AnAggregationStrategythat adapts to aBiFunction.AggregationStrategyMethodInfo Method information about the POJO method to call when using theAggregationStrategyBeanAdapter.AggregationStrategyParameterInfo Parameter information to be used for method invocation.CatchProcessor A processor which catches exceptions.ChoiceProcessor 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.ClaimCheckAggregationStrategy DefaultAggregationStrategyused by theClaimCheckProcessorEIP.ClaimCheckProcessor ClaimCheck EIP implementation.ClosedCorrelationKeyException The correlation key has been closed and the Exchange cannot be aggregated.ContractAdvice ACamelInternalProcessorAdvicewhich appliesTransformerandValidatoraccording to the data type Contract.DataFormatTransformer ATransformerimplementation which leveragesDataFormatto perform transformation.DeadLetterChannel Implements a Dead Letter Channel after attempting to redeliver the message using theRedeliveryPolicyDefaultAggregateController A defaultAggregateControllerthat offers Java and JMX API.DefaultAnnotationBasedProcessorFactory DefaultClaimCheckRepository The defaultClaimCheckRepositoryimplementation that is an in-memory storage.DefaultDeferServiceFactory DefaultErrorHandler Default error handlerDefaultExceptionPolicyStrategy The default strategy used in Camel to resolve theExceptionPolicyKeythat should handle the thrown exception.DefaultExchangeComparator Compares elements of anExchangesequence by comparinglongvalues returned by this comparator'sexpression.DefaultInternalProcessorFactory DefaultProcessorFactory DefaultProcessorFactorythat supports using 3rd party Camel components to implement the EIPProcessor.Delayer A Delayer which delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.DelayProcessorSupport A useful base class for any processor which provides some kind of throttling or delayed processing.DisabledProcessor A disabled EIP that does not do anythingDistributionRatio DynamicRouter Implements a Dynamic Router pattern where the destination(s) is computed at runtime.Enricher A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpointproducerand second by aggregating input data and additional data.ErrorHandlerSupport Support class forErrorHandlerimplementations.EvaluateExpressionProcessor AProcessorwhich evaluates anExpressionand stores the result as a property on theExchangewith the keyExchange.EVALUATE_EXPRESSION_RESULT.EventNotifierProducer Ensures aProducerdo sendEventNotifiernotifications when sending.ExceptionFailureStatistics Statistics about exception failures for load balancers that reacts on exceptionsExceptionPolicy ExceptionPolicy.RedeliveryOption ExceptionPolicyKey Exception policy key is a compound key for storing: route id + exception class + when => exception type.ExceptionPolicyStrategy A strategy to determine whichExceptionPolicyKeyshould handle the thrown exception.ExchangePatternProcessor Processor to setExchangePatternon theExchange.ExpressionResultComparator ASequenceElementComparatorthat comparesExchanges based on the result of an expression evaluation.FailOverLoadBalancer This FailOverLoadBalancer will failover to use next processor when an exception occurredFatalFallbackErrorHandler AnErrorHandlerused as a safe fallback when processing by other error handlers such as theorg.apache.camel.model.OnExceptionDefinition.FilterProcessor The processor which implements the Message Filter EIP pattern.FinallyProcessor Processor to handle do finally supporting asynchronous routing engineGroupedBodyAggregationStrategy GroupedExchangeAggregationStrategy Aggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in aListofExchangeas the message body.GroupedMessageAggregationStrategy Aggregate allMessageinto a single combined Exchange holding all the aggregated messages in aListofMessageas the message body.IdempotentConsumer An implementation of the Idempotent Consumer pattern.IdempotentOnCompletion On completion strategy forIdempotentConsumer.InterceptEndpointProcessor Endpoint intercept processor so we know the processor is supposed to intercept an endpoint.InterceptSendToEndpointCallback Endpoint strategy used by intercept send to endpoint.InterceptSendToEndpointProcessor Processorused to interceptor and detour the routing when using theDefaultInterceptSendToEndpointfunctionality.LoadBalancer A strategy for load balancing across a number ofProcessorinstancesLoadBalancerConsumer Represents a consumer which on starting registers itself with aLoadBalancerand on closing unregisters itself with a load balancerLoadBalancerSupport A default base class for aLoadBalancerimplementation.LogProcessor A processor which evaluates anExpressionand logs it.LoopProcessor The processor which sends messages in a loop.MandatorySagaProcessor Saga processor implementing the MANDATORY propagation mode.MemoryAggregationRepository A memory basedAggregationRepositorywhich storesExchanges in memory only.MessageRejectedException An exception thrown if message is rejected by the resequencerMulticastProcessor Implements the Multicast pattern to send a message exchange to a number of endpoints, each endpoint receiving a copy of the message exchange.NeverSagaProcessor Saga processor implementing the NEVER propagation mode.NoErrorHandler NoMessageIdException An exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.NoOffsetException An exception thrown if no camel offset header could be found on the message.NotSupportedSagaProcessor Saga processor implementing the NOT_SUPPORTED propagation mode.OnCompletionProcessor Processor implementing onCompletion.OptimisticLockRetryPolicy Class to control how failed optimistic locks are tried.PausableProcessor Pipeline Creates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchangesPipelineHelper Helper for processingExchangein a pipeline.PollEnricher A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpointproducerand second by aggregating input data and additional data.PooledExchangeTask A task that EIPs and internal routing engine uses to store state when processing anExchange.PooledExchangeTaskFactory Factory to createPooledExchangeTask.PooledTaskFactory ProcessorExchangePair Exchange pair to be executed byMulticastProcessor.ProcessorTransformer ATransformerimplementation which leveragesProcessorto perform transformation.ProcessorValidator AValidatorimplementation which leveragesProcessorto perform validation.PrototypeTaskFactory QueueLoadBalancer A base class forLoadBalancerimplementations which choose a single destination for each exchange (rather like JMS Queues)RandomLoadBalancer Implements the random load balancing policyRecipientList 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 Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.RedeliveryErrorHandler Base redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.RedeliveryPolicy The policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead Letter ChannelRedeliveryPolicyConfigurer Generated by camel build tools - do NOT edit this file!RemoveHeaderProcessor A processor which removes the header from the IN or OUT messageRemoveHeadersProcessor A processor which removes one ore more headers from the IN or OUT messageRemovePropertiesProcessor A processor which removes one ore more properties from the exchangeRemovePropertyProcessor A processor which removes the property from the exchangeRequiredSagaProcessor Saga processor implementing the REQUIRED propagation mode.RequiresNewSagaProcessor Saga processor implementing the REQUIRES_NEW propagation mode.Resequencer An implementation of the Resequencer which can reorder messages within a batch.ResequencerEngine<E> Resequences elements based on a givenSequenceElementComparator.RestBindingAdvice ACamelInternalProcessorAdvicethat binds the REST DSL incoming and outgoing messages from sources of json or xml to Java Objects.ResumableCompletion ResumableProcessor Resume EIPRollbackProcessor Processor for marking anExchangeto rollback.RoundRobinLoadBalancer Implements the round robin load balancing policyRoutePipeline Pipelineused as starting point forRoute.RoutingSlip 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.RoutingSlipIterator The iterator to be used for retrieving the next routing slip(s) to be used.SagaCompletionMode Enumerates all saga completion modes.SagaProcessor Processor for handling sagas.SagaProcessorBuilder Builder of Saga processors.SagaPropagation Enumerates all saga propagation modes.SamplingThrottler ASamplingThrottleris a special kind of throttler.ScriptProcessor A processor which executes the script as an expression and does not change the message body.SendDynamicAwareResolver SendDynamicProcessor Processor for forwarding exchanges to a dynamic endpoint destination.SendProcessor Processor for forwarding exchanges to a static endpoint destination.Sequence<E> A sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.SequenceElementComparator<E> A strategy for comparing elements of a sequence.SequenceSender<E> An interface used by theResequencerEngine.deliver()andResequencerEngine.deliverNext()methods to send out re-ordered elements.SetBodyProcessor A processor which sets the body on the IN or OUT message with anExpressionSetHeaderProcessor A processor which sets the header on the IN or OUT message with anExpressionSetPropertyProcessor A processor which sets the property on the exchange with anExpressionShareUnitOfWorkAggregationStrategy AnAggregationStrategywhich are used when the option shareUnitOfWork is enabled on EIPs such as multicast, splitter or recipientList.SortProcessor<T> A processor that sorts the expression using a comparatorSplitter 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.StepProcessor StickyLoadBalancer Implements a sticky load balancer using anExpressionto calculate a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.StopProcessor Stops continue processing the route and marks it as complete.StreamResequencer A resequencer that re-orders a (continuous) stream ofExchanges.StringAggregationStrategy Aggregate result of pick expression into a single combined Exchange holding all the aggregated bodies in aStringas the message body.SupportsSagaProcessor Saga processor implementing the SUPPORTS propagation mode.ThreadsProcessor Threads processor that leverage a thread pool for continue processing theExchanges using the asynchronous routing engine.Throttler 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.ThrottlerRejectedExecutionException ThrowExceptionProcessor The processor which sets anExceptionon theExchangeTimeout A timer task that notifies handlers about scheduled timeouts.TimeoutHandler Implemented by classes that handle timeout notifications.TopicLoadBalancer ALoadBalancerimplementations which sends to all destinations (rather like JMS Topics).TransformProcessor A processor which sets the body on the OUT message with anExpression.TransientResumeStrategy A resume strategy that keeps all the resume strategy information in memory.TryProcessor Implements try/catch/finally type processingUnitOfWorkProducer Ensures aProduceris executed within anUnitOfWork.UseLatestAggregationStrategy AnAggregationStrategywhich just uses the latest exchange which is useful for status messages where old status messages have no real value.UseOriginalAggregationStrategy AnAggregationStrategywhich just uses the original exchange which can be needed when you want to preserve the original Exchange.WeightedLoadBalancer WeightedRandomLoadBalancer WeightedRoundRobinLoadBalancer WireTapProcessor Processor for wire tapping exchanges to an endpoint destination.WrapProcessor A processor which ensures wrapping processors is having lifecycle handled.