Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.camel.processor Classes and Interfaces - 163 results found.
NameDescriptionTypePackageFramework
AbstractListAggregationStrategyAggregate all exchanges into a List of values defined by the getValue(Exchange) call.Classorg.apache.camel.processor.aggregateApache Camel
AggregateProcessorAn implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount orClassorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyA strategy for aggregating two exchanges together into a single exchange.Interfaceorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyBeanAdapterAn AggregationStrategy that adapts to a POJO.Classorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyBeanInfoClass information about the POJO method to call when using the AggregationStrategyBeanAdapter.Classorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyMethodInfoMethod information about the POJO method to call when using the AggregationStrategyBeanAdapter.Classorg.apache.camel.processor.aggregateApache Camel
AOPProcessorClassorg.apache.camel.processorApache Camel
BacklogDebuggerA Debugger that has easy debugging functionality which can be used from JMX with ManagedBacklogDebuggerMBean.Classorg.apache.camel.processor.interceptorApache Camel
BacklogTracerA tracer used for message tracing, storing a copy of the message details in a backlog.Classorg.apache.camel.processor.interceptorApache Camel
BatchProcessorA base class for any kind of Processor which implements some kind of batch processing.Classorg.apache.camel.processorApache Camel
BindingExceptionAn exception if a binding is not possible, such as binding to json or xml cannot be done.Classorg.apache.camel.processor.bindingApache Camel
CamelInternalProcessorInternal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWorkKeeping track which route currently is being routedExecute RoutePolicyGather JMX performance staticsTracingDebuggingMessage HistoryStream CachingClassorg.apache.camel.processorApache Camel
CamelInternalProcessor .BacklogDebuggerAdviceAdvice to execute the BacklogDebugger if enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .BacklogTracerAdviceAdvice to execute the BacklogTracer if enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .ChildUnitOfWorkProcessorAdviceAdvice when an EIP uses the shareUnitOfWork functionality.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .DelayerAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .InstrumentationAdviceAdvice for JMX instrumentation of the process being invoked.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .MessageHistoryAdviceAdvice when Message History has been enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteContextAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteInflightRepositoryAdviceAdvice to keep the InflightRepository up to date.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteLifecycleAdviceAdvice to invoke callbacks for before and after routing.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RoutePolicyAdviceAdvice to execute any RoutePolicy a route may have been configured with.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .StreamCachingAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .SubUnitOfWorkProcessorAdviceAdvice when an EIP uses the shareUnitOfWork functionality.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .UnitOfWorkProcessorAdviceAdvice to inject new UnitOfWork to the Exchange if needed, and as well to ensure the UnitOfWork is done and stopped.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessorAdviceAn advice (before and after) to execute cross cutting functionality in the Camel routing engine.Interfaceorg.apache.camel.processorApache Camel
CamelLoggerA Processor which just logs to a CamelLogger object which can be used as an exception handler instead of using a dead letter queue.Classorg.apache.camel.processorApache Camel
CamelLogProcessorA Processor which just logs to a CamelLogger object which can be used as an exception handler instead of using a dead letter queue.Classorg.apache.camel.processorApache Camel
CatchProcessorA processor which catches exceptions.Classorg.apache.camel.processorApache Camel
ChoiceProcessorClassorg.apache.camel.processorApache Camel
CircuitBreakerLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
ClosedCorrelationKeyExceptionThe correlation key has been closed and the Exchange cannot be aggregated.Classorg.apache.camel.processor.aggregateApache Camel
CompletionAwareAggregationStrategyA specialized AggregationStrategy which has callback when the aggregated Exchange is completed.Interfaceorg.apache.camel.processor.aggregateApache Camel
ConvertBodyProcessorA processor which converts the payload of the input message to be of the given type If the conversion fails an InvalidPayloadException is thrown.Classorg.apache.camel.processorApache Camel
DataFormatBindingRepresents a Binding which Marshals the message in the ProduceProcessor and Unmarshals the message in the ConsumeProcessorClassorg.apache.camel.processor.bindingApache Camel
DeadLetterChannelClassorg.apache.camel.processorApache Camel
DebugA debug interceptor to notify Debugger with Exchanges being processed.Classorg.apache.camel.processor.interceptorApache Camel
DefaultBacklogTracerEventMessageAn event message holding the traced message by the BacklogTracer.Classorg.apache.camel.processor.interceptorApache Camel
DefaultChannelDefaultChannel is the default Channel.Classorg.apache.camel.processor.interceptorApache Camel
DefaultErrorHandlerClassorg.apache.camel.processorApache Camel
DefaultExceptionPolicyStrategyThe default strategy used in Camel to resolve the OnExceptionDefinition that should handle the thrown exception.Classorg.apache.camel.processor.exceptionpolicyApache Camel
DefaultExchangeComparatorCompares elements of an Exchange sequence by comparing long values returned by this comparator'sClassorg.apache.camel.processor.resequencerApache Camel
DefaultExchangeFormatterDefault ExchangeFormatter that have fine grained options to configure what to include in the output.Classorg.apache.camel.processorApache Camel
DefaultExchangeFormatter .OutputStyleClassorg.apache.camel.processor.DefaultExchangeFormatterApache Camel
DefaultTraceEventHandlerClassorg.apache.camel.processor.interceptorApache Camel
DefaultTraceEventMessageDefault TraceEventMessage.Classorg.apache.camel.processor.interceptorApache Camel
DefaultTraceFormatterClassorg.apache.camel.processor.interceptorApache Camel
DefaultTraceInterceptorFactoryClassorg.apache.camel.processor.interceptorApache Camel
DefaultValidationErrorHandlerA default error handler which just stores all the errors so they can be reported or transformed.Classorg.apache.camel.processor.validationApache Camel
Delayer delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.Classorg.apache.camel.processorApache Camel
DelayerAn interceptor strategy for delaying routes.Classorg.apache.camel.processor.interceptorApache Camel
DelayInterceptorAn interceptor for delaying routes.Classorg.apache.camel.processor.interceptorApache Camel
DelayProcessorSupportA useful base class for any processor which provides some kind of throttling or delayed processing.Classorg.apache.camel.processorApache Camel
DelegateAsyncProcessorA Delegate pattern which delegates processing to a nested AsyncProcessor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DelegateProcessorA Delegate pattern which delegates processing to a nested Processor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DelegateSyncProcessorA Delegate pattern which delegates synchronous processing to a nested Processor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DistributionRatioClassorg.apache.camel.processor.loadbalancerApache Camel
DynamicRouter where the destination(s) is computed at runtime.Classorg.apache.camel.processorApache Camel
EnricherA content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producerClassorg.apache.camel.processorApache Camel
ErrorHandlerSupportSupport class for ErrorHandler implementations.Classorg.apache.camel.processorApache Camel
EvaluateExpressionProcessorA Processor which evaluates an Expression and stores the result as a property on the Exchange with the keyClassorg.apache.camel.processorApache Camel
ExceptionPolicyKeyException policy key is a compound key for storing: route id + exception class + when => exception type.Classorg.apache.camel.processor.exceptionpolicyApache Camel
ExceptionPolicyStrategyA strategy to determine which OnExceptionDefinition should handle the thrownSee Also:DefaultExceptionPolicyInterfaceorg.apache.camel.processor.exceptionpolicyApache Camel
ExchangePatternProcessorProcessor to set ExchangePattern on the Exchange.Classorg.apache.camel.processorApache Camel
ExpressionResultComparatorA SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.Interfaceorg.apache.camel.processor.resequencerApache Camel
FailOverLoadBalancerThis FailOverLoadBalancer will failover to use next processor when an exception occurred This implementation mirrors the logic from the Pipeline in the async variationClassorg.apache.camel.processor.loadbalancerApache Camel
FatalFallbackErrorHandlerAn ErrorHandler used as a safe fallback when processing by other error handlers such as the OnExceptionDefinition.Classorg.apache.camel.processorApache Camel
FileIdempotentRepositoryA file based implementation of IdempotentRepository.Classorg.apache.camel.processor.idempotentApache Camel
FilterProcessorThe processor which implements the Message Filter EIP pattern.Classorg.apache.camel.processorApache Camel
FinallyProcessorClassorg.apache.camel.processorApache Camel
GroupedExchangeAggregationStrategyAggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in a List of Exchange as the message body.Classorg.apache.camel.processor.aggregateApache Camel
HandleFaultClassorg.apache.camel.processor.interceptorApache Camel
HandleFaultInterceptorClassorg.apache.camel.processor.interceptorApache Camel
IdempotentConsumerAn implementation of the Idempotent Consumer pattern.Classorg.apache.camel.processor.idempotentApache Camel
IdempotentOnCompletionOn completion strategy for IdempotentConsumer.Classorg.apache.camel.processor.idempotentApache Camel
InterceptEndpointProcessorEndpoint intercept processor so we know the processor is supposed to intercept an endpoint.Classorg.apache.camel.processorApache Camel
InterceptorToAsyncProcessorBridgeA bridge to have regular interceptors implemented as Processor work with the asynchronous routing engine without causing side effects.Classorg.apache.camel.processorApache Camel
LoadBalancerInterfaceorg.apache.camel.processor.loadbalancerApache Camel
LoadBalancerConsumerRepresents a consumer which on starting registers itself with a LoadBalancer and on closing unregisters itself with a load balancerClassorg.apache.camel.processor.loadbalancerApache Camel
LoadBalancerSupportA default base class for a LoadBalancer implementation.Classorg.apache.camel.processor.loadbalancerApache Camel
LoggingErrorHandlerClassorg.apache.camel.processorApache Camel
LogProcessorA processor which evaluates an Expression and logs it.Classorg.apache.camel.processorApache Camel
LoopProcessorThe processor which sends messages in a loop.Classorg.apache.camel.processorApache Camel
MarshalProcessorClassorg.apache.camel.processorApache Camel
MemoryAggregationRepositoryA memory based AggregationRepository which stores Exchanges in memory only.Classorg.apache.camel.processor.aggregateApache Camel
MemoryIdempotentRepositoryA memory based implementation of IdempotentRepository.Classorg.apache.camel.processor.idempotentApache Camel
MessageRejectedExceptionAn exception thrown if message is rejected by the resequencerVersion:See Also:Serialized FormClassorg.apache.camel.processor.resequencerApache Camel
MulticastProcessor endpoints, each endpoint receiving a copy of the message exchange.Classorg.apache.camel.processorApache Camel
NoMessageIdExceptionAn exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.Classorg.apache.camel.processor.idempotentApache Camel
NoXmlBodyValidationExceptionAn exception found if no XML body is available on the inbound messageVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
NoXmlHeaderValidationExceptionAn exception thrown if the XML header is not available on the inbound messageVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
OnCompletionProcessorProcessor implementing onCompletion.Classorg.apache.camel.processorApache Camel
OptimisticLockingAwareAggregationStrategyA specialized AggregationStrategy which gets a callback when the aggregated Exchange fails to add in the OptimisticLockingAggregationRepository because ofInterfaceorg.apache.camel.processor.aggregateApache Camel
OptimisticLockRetryPolicyClass to control how failed optimistic locks are tried.Classorg.apache.camel.processor.aggregateApache Camel
PipelineCreates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchangesClassorg.apache.camel.processorApache Camel
PipelineHelperClassorg.apache.camel.processorApache Camel
PollEnricherA content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producerClassorg.apache.camel.processorApache Camel
PredicateValidatingProcessorA processor which validates the content of the inbound message body against a Predicate.Classorg.apache.camel.processor.validationApache Camel
PredicateValidationExceptionA predicate validation exception occurredVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
ProcessorA processor is used to implement the Event Driven ConsumerInterfaceorg.apache.camelApache Camel
ProcessorExchangePairExchange pair to be executed by MulticastProcessor.Interfaceorg.apache.camel.processorApache Camel
QueueLoadBalancerA base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)Classorg.apache.camel.processor.loadbalancerApache Camel
RandomLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
RecipientList pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.Classorg.apache.camel.processorApache Camel
RecipientListProcessor pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.Classorg.apache.camel.processorApache Camel
RedeliveryErrorHandlerBase redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.Classorg.apache.camel.processorApache Camel
RedeliveryPolicyThe policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead LetterClassorg.apache.camel.processorApache Camel
RemoveHeaderProcessorClassorg.apache.camel.processorApache Camel
RemoveHeadersProcessorClassorg.apache.camel.processorApache Camel
RemovePropertiesProcessorClassorg.apache.camel.processorApache Camel
RemovePropertyProcessorClassorg.apache.camel.processorApache Camel
ResequencerAn implementation of the Resequencer which can reorder messages within a batch.Classorg.apache.camel.processorApache Camel
ResequencerEngineResequences elements based on a given SequenceElementComparator.Classorg.apache.camel.processor.resequencerApache Camel
RestBindingProcessorA Processor that binds the REST DSL incoming and outgoing messages from sources of json or xml to Java Objects.Classorg.apache.camel.processor.bindingApache Camel
RollbackProcessorProcessor for marking an Exchange to rollback.Classorg.apache.camel.processorApache Camel
RoundRobinLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
RoutingSlip pattern where the list of actual endpoints to send a message exchange to are dependent on the value of a message header.Classorg.apache.camel.processorApache Camel
RoutingSlip .RoutingSlipIteratorThe iterator to be used for retrieving the next routing slip(s) to be used.Interfaceorg.apache.camel.processor.RoutingSlipApache Camel
SamplingThrottlerA SamplingThrottler is a special kind of throttler.Classorg.apache.camel.processorApache Camel
SchemaValidationExceptionA Schema validation exception occurredVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
SendProcessorProcessor for forwarding exchanges to an endpoint destination.Classorg.apache.camel.processorApache Camel
SequenceA sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.Classorg.apache.camel.processor.resequencerApache Camel
SequenceElementComparatorA strategy for comparing elements of a sequence.Interfaceorg.apache.camel.processor.resequencerApache Camel
SequenceSenderAn interface used by the ResequencerEngine.Interfaceorg.apache.camel.processor.resequencerApache Camel
SetBodyProcessorClassorg.apache.camel.processorApache Camel
SetHeaderProcessorClassorg.apache.camel.processorApache Camel
SetPropertyProcessorClassorg.apache.camel.processorApache Camel
SimpleLoadBalancerSupportA default base class for a LoadBalancer implementation.Classorg.apache.camel.processor.loadbalancerApache Camel
SortProcessorClassorg.apache.camel.processorApache Camel
Splitter 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.Classorg.apache.camel.processorApache Camel
StickyLoadBalancer a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.Classorg.apache.camel.processor.loadbalancerApache Camel
StopProcessorStops continue processing the route and marks it as complete.Classorg.apache.camel.processorApache Camel
StreamCachingClassorg.apache.camel.processor.interceptorApache Camel
StreamCachingInterceptorAn interceptor that converts streams messages into a re-readable format by wrapping the stream into a StreamCache.Classorg.apache.camel.processor.interceptorApache Camel
StreamResequencerA resequencer that re-orders a (continuous) stream of Exchanges.Classorg.apache.camel.processorApache Camel
ThreadsProcessorThreads processor that leverage a thread pool for continue processing the Exchanges using the asynchronous routing engine.Classorg.apache.camel.processorApache Camel
Throttler will set a limit on the maximum number of message exchanges which can be sent to a processor within a specific time period.Classorg.apache.camel.processorApache Camel
ThrottlerRejectedExecutionExceptionClassorg.apache.camel.processorApache Camel
ThroughputLoggerA logger for logging message throughput.Classorg.apache.camel.processorApache Camel
ThrowExceptionProcessorClassorg.apache.camel.processorApache Camel
TimeoutA timer task that notifies handlers about scheduled timeouts.Classorg.apache.camel.processor.resequencerApache Camel
TimeoutAwareAggregationStrategyA specialized AggregationStrategy which can handle timeouts as well.Interfaceorg.apache.camel.processor.aggregateApache Camel
TimeoutHandlerInterfaceorg.apache.camel.processor.resequencerApache Camel
TopicLoadBalancerA LoadBalancer implementations which sends to all destinations (rather like JMS Topics).Classorg.apache.camel.processor.loadbalancerApache Camel
TraceEventHandlerA handler which reacts on trace events.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceEventMessageA trace event message that contains decomposed information about the traced Exchange at the point of interception.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceFormatterFormatter to format trace logs when tracing Exchange during routing.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceInterceptorClassorg.apache.camel.processor.interceptorApache Camel
TraceInterceptorFactoryFactory to create the trace interceptor.Interfaceorg.apache.camel.processor.interceptorApache Camel
TracerClassorg.apache.camel.processor.interceptorApache Camel
TransformProcessorClassorg.apache.camel.processorApache Camel
TryProcessorClassorg.apache.camel.processorApache Camel
UnitOfWorkProducerEnsures a Producer is executed within an UnitOfWork.Classorg.apache.camel.processorApache Camel
UnmarshalProcessorClassorg.apache.camel.processorApache Camel
UseLatestAggregationStrategyAn AggregationStrategy which just uses the latest exchange which is useful for status messages where old status messages have no real value.Classorg.apache.camel.processor.aggregateApache Camel
UseOriginalAggregationStrategyAn AggregationStrategy which just uses the original exchange which can be needed when you want to preserve the original Exchange.Classorg.apache.camel.processor.aggregateApache Camel
ValidatingProcessorA processor which validates the XML version of the inbound message body against some schema either in XSD or RelaxNGClassorg.apache.camel.processor.validationApache Camel
ValidatorErrorHandlerValidator error handler.Interfaceorg.apache.camel.processor.validationApache Camel
WeightedLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WeightedRandomLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WeightedRoundRobinLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WireTapProcessorProcessor for wire tapping exchanges to an endpoint destination.Classorg.apache.camel.processorApache Camel
WrapProcessorA processor which ensures wrapping processors is having lifecycle handled.Classorg.apache.camel.processorApache Camel