Uses of Interface
org.apache.camel.AsyncProcessor

Packages that use AsyncProcessor
org.apache.camel The core Camel API. 
org.apache.camel.component.bean The Bean Component which will look up the bean name in the Spring ApplicationContext and use that to dispatch messages to a POJO 
org.apache.camel.component.controlbus The Control Bus Component which allows to manage Camel at runtime. 
org.apache.camel.component.direct The Direct Component which synchronously invokes all the consumers when a producer sends an exchange to the endpoint. 
org.apache.camel.component.directvm The Direct VM Component which synchronously invokes the consumer when a producer sends an exchange to the endpoint. 
org.apache.camel.component.log The Log Component uses Jakarta Commons Logging to log message exchanges. 
org.apache.camel.component.seda The SEDA Component for asynchronous SEDA exchanges on a BlockingQueue within a single CamelContext 
org.apache.camel.impl Default implementation classes for Camel Core 
org.apache.camel.impl.converter Default implementation classes the Type Conversion Strategies 
org.apache.camel.management Camel management 
org.apache.camel.model The JAXB POJOs for the XML Configuration of the routing rules. 
org.apache.camel.model.loadbalancer The JAXB POJOs for the Load Balancer EIP pattern for the XML Configuration
org.apache.camel.processor A collection of Processor implementations which are used to implement the Enterprise Integration Patterns 
org.apache.camel.processor.aggregate Helper classes for the Aggregator pattern. 
org.apache.camel.processor.idempotent An implementation of the Idempotent Consumer pattern. 
org.apache.camel.processor.interceptor Helper classes for interceptors. 
org.apache.camel.processor.loadbalancer Various load balancer processors 
org.apache.camel.processor.validation Performs XML validation using JAXP for validating against XSD or RelaxNG 
org.apache.camel.util Utility classes used by the core of Camel. 
 

Uses of AsyncProcessor in org.apache.camel
 

Subinterfaces of AsyncProcessor in org.apache.camel
 interface Channel
          Channel acts as a channel between Processors in the route graph.
 

Methods in org.apache.camel with parameters of type AsyncProcessor
 boolean AsyncProducerCallback.doInAsyncProducer(Producer producer, AsyncProcessor asyncProducer, Exchange exchange, ExchangePattern exchangePattern, AsyncCallback callback)
          Performs operation on the given producer to send the given exchange.
 

Uses of AsyncProcessor in org.apache.camel.component.bean
 

Classes in org.apache.camel.component.bean that implement AsyncProcessor
 class BeanProcessor
          A Processor which converts the inbound exchange to a method invocation on a POJO
 

Uses of AsyncProcessor in org.apache.camel.component.controlbus
 

Classes in org.apache.camel.component.controlbus that implement AsyncProcessor
 class ControlBusProducer
          The control bus producer.
 

Uses of AsyncProcessor in org.apache.camel.component.direct
 

Classes in org.apache.camel.component.direct that implement AsyncProcessor
 class DirectBlockingProducer
          The direct producer.
 class DirectProducer
          The direct producer.
 

Uses of AsyncProcessor in org.apache.camel.component.directvm
 

Classes in org.apache.camel.component.directvm that implement AsyncProcessor
 class DirectVmBlockingProducer
          The direct producer.
 class DirectVmProcessor
           
 class DirectVmProducer
          The direct-vm producer
 

Uses of AsyncProcessor in org.apache.camel.component.log
 

Classes in org.apache.camel.component.log that implement AsyncProcessor
 class LogProducer
          Log producer.
 

Uses of AsyncProcessor in org.apache.camel.component.seda
 

Classes in org.apache.camel.component.seda that implement AsyncProcessor
 class CollectionProducer
          Deprecated. will be removed in a future Camel release
 class SedaProducer
           
 

Uses of AsyncProcessor in org.apache.camel.impl
 

Classes in org.apache.camel.impl that implement AsyncProcessor
 class DefaultAsyncProducer
          A default implementation of Producer for implementation inheritance, which can process Exchanges asynchronously.
 

Methods in org.apache.camel.impl that return AsyncProcessor
 AsyncProcessor DefaultConsumer.getAsyncProcessor()
          Provides an AsyncProcessor interface to the configured processor on the consumer.
 

Uses of AsyncProcessor in org.apache.camel.impl.converter
 

Methods in org.apache.camel.impl.converter that return AsyncProcessor
static AsyncProcessor AsyncProcessorTypeConverter.convert(Processor value)
          Deprecated. use AsyncProcessorConverterHelper.convert(org.apache.camel.Processor) instead
 

Uses of AsyncProcessor in org.apache.camel.management
 

Classes in org.apache.camel.management that implement AsyncProcessor
 class InstrumentationProcessor
          JMX enabled processor that uses the ManagedCounter for instrumenting processing of exchanges.
 

Uses of AsyncProcessor in org.apache.camel.model
 

Subinterfaces of AsyncProcessor in org.apache.camel.model
 interface ModelChannel
           
 

Classes in org.apache.camel.model that implement AsyncProcessor
 class LoadBalancerDefinition
          Represents an XML <loadBalancer/> element
 

Uses of AsyncProcessor in org.apache.camel.model.loadbalancer
 

Classes in org.apache.camel.model.loadbalancer that implement AsyncProcessor
 class CustomLoadBalancerDefinition
          Represents an XML <customLoadBalancer/> element
 class FailoverLoadBalancerDefinition
          Represents an XML <failover/> element
 class RandomLoadBalancerDefinition
          Represents an XML <random/> element
 class RoundRobinLoadBalancerDefinition
          Represents an XML <roundRobin/> element
 class StickyLoadBalancerDefinition
          Represents an XML <sticky/> element
 class TopicLoadBalancerDefinition
          Represents an XML <topic/> element
 class WeightedLoadBalancerDefinition
          Represents an XML <weighted/> element
 

Uses of AsyncProcessor in org.apache.camel.processor
 

Classes in org.apache.camel.processor that implement AsyncProcessor
 class AOPProcessor
           
 class BatchProcessor
          Deprecated. may be removed in the future when we overhaul the resequencer EIP
 class CamelInternalProcessor
          Internal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWork Keeping track which route currently is being routed Execute RoutePolicy Gather JMX performance statics Tracing Debugging Message History Stream Caching ...
 class CamelLogger
          Deprecated. This class has been split up into org.apache.camel.util.CamelLogger and org.apache.camel.processor.CamelLogProcessor
 class CamelLogProcessor
          A Processor which just logs to a CamelLogger object which can be used as an exception handler instead of using a dead letter queue.
 class CatchProcessor
          A processor which catches exceptions.
 class 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.
 class ConvertBodyProcessor
          A processor which converts the payload of the input message to be of the given type

If the conversion fails an InvalidPayloadException is thrown.

 class DeadLetterChannel
          Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
 class DefaultErrorHandler
          Default error handler
 class Delayer
          A Delayer which delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.
 class DelayProcessorSupport
          A useful base class for any processor which provides some kind of throttling or delayed processing.
 class DelegateAsyncProcessor
          A Delegate pattern which delegates processing to a nested AsyncProcessor which can be useful for implementation inheritance when writing an Policy

Important: This implementation does support the asynchronous routing engine.

 class DelegateSyncProcessor
          A Delegate pattern which delegates synchronous processing to a nested Processor which can be useful for implementation inheritance when writing an Policy

Important: This implementation does support the asynchronous routing engine, only.

 class DynamicRouter
          Implements a Dynamic Router pattern where the destination(s) is computed at runtime.
 class Enricher
          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.
 class EvaluateExpressionProcessor
          A Processor which evaluates an Expression and stores the result as a property on the Exchange with the key Exchange.EVALUATE_EXPRESSION_RESULT.
 class ExchangePatternProcessor
           
 class FatalFallbackErrorHandler
          An ErrorHandler used as a safe fallback when processing by other error handlers such as the OnExceptionDefinition.
 class FilterProcessor
          The processor which implements the Message Filter EIP pattern.
 class FinallyProcessor
          Processor to handle do finally supporting asynchronous routing engine
 class InterceptEndpointProcessor
          Endpoint intercept processor so we know the processor is supposed to intercept an endpoint.
 class InterceptorToAsyncProcessorBridge
          A bridge to have regular interceptors implemented as Processor work with the asynchronous routing engine without causing side effects.
 class LoggingErrorHandler
          An ErrorHandler which uses commons-logging to dump the error
 class LogProcessor
          A processor which evaluates an Expression and logs it.
 class LoopProcessor
          The processor which sends messages in a loop.
 class MarshalProcessor
          Marshals the body of the incoming message using the given data format
 class MulticastProcessor
          Implements the Multicast pattern to send a message exchange to a number of endpoints, each endpoint receiving a copy of the message exchange.
 class OnCompletionProcessor
           
 class Pipeline
          Creates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchanges
 class PollEnricher
          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.
 class RecipientList
          Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
 class 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.
 class RedeliveryErrorHandler
          Base redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.
 class Resequencer
          An implementation of the Resequencer which can reorder messages within a batch.
 class RollbackProcessor
          Processor for marking an Exchange to rollback.
 class 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.
 class SamplingThrottler
          A SamplingThrottler is a special kind of throttler.
 class SendProcessor
          Processor for forwarding exchanges to an endpoint destination.
 class SetBodyProcessor
          A processor which sets the body on the IN or OUT message with an Expression
 class SortProcessor<T>
          A processor that sorts the expression using a comparator
 class Splitter
          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.
 class StopProcessor
          Stops continue processing the route and marks it as complete.
 class StreamResequencer
          A resequencer that re-orders a (continuous) stream of Exchanges.
 class ThreadsProcessor
          Threads processor that leverage a thread pool for continue processing the Exchanges using the asynchronous routing engine.
 class 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.
 class ThroughputLogger
          A logger for logging message throughput.
 class ThrowExceptionProcessor
          The processor which sets an Exception on the Exchange
 class TransformProcessor
          A processor which sets the body on the OUT message with an Expression
 class TryProcessor
          Implements try/catch/finally type processing
 class UnmarshalProcessor
          Unmarshals the body of the incoming message using the given data format
 class WireTapProcessor
          Processor for wire tapping exchanges to an endpoint destination.
 class WrapProcessor
          A processor which ensures wrapping processors is having lifecycle handled.
 

Fields in org.apache.camel.processor declared as AsyncProcessor
protected  AsyncProcessor RedeliveryErrorHandler.outputAsync
           
protected  AsyncProcessor DelegateAsyncProcessor.processor
           
protected  AsyncProcessor SendProcessor.producer
           
 

Methods in org.apache.camel.processor that return AsyncProcessor
 AsyncProcessor DelegateAsyncProcessor.getProcessor()
           
 

Methods in org.apache.camel.processor with parameters of type AsyncProcessor
protected  boolean TryProcessor.process(Exchange exchange, AsyncCallback callback, Iterator<Processor> processors, AsyncProcessor processor, Object lastHandled)
           
 void DelegateAsyncProcessor.setProcessor(AsyncProcessor processor)
           
 

Constructors in org.apache.camel.processor with parameters of type AsyncProcessor
DelegateAsyncProcessor(AsyncProcessor processor)
           
InterceptorToAsyncProcessorBridge(Processor interceptor, AsyncProcessor target)
          Constructs the bridge
 

Uses of AsyncProcessor in org.apache.camel.processor.aggregate
 

Classes in org.apache.camel.processor.aggregate that implement AsyncProcessor
 class 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 of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
 

Uses of AsyncProcessor in org.apache.camel.processor.idempotent
 

Classes in org.apache.camel.processor.idempotent that implement AsyncProcessor
 class IdempotentConsumer
          An implementation of the Idempotent Consumer pattern.
 

Uses of AsyncProcessor in org.apache.camel.processor.interceptor
 

Classes in org.apache.camel.processor.interceptor that implement AsyncProcessor
 class DefaultChannel
          DefaultChannel is the default Channel.
 class DelayInterceptor
          Deprecated. no longer in use, will be removed in next Camel release.
 class HandleFaultInterceptor
           
 class StreamCachingInterceptor
          Deprecated. no longer in use, will be removed in next Camel release.
 class TraceInterceptor
          An interceptor for debugging and tracing routes
 

Uses of AsyncProcessor in org.apache.camel.processor.loadbalancer
 

Subinterfaces of AsyncProcessor in org.apache.camel.processor.loadbalancer
 interface LoadBalancer
          A strategy for load balancing across a number of Processor instances
 

Classes in org.apache.camel.processor.loadbalancer that implement AsyncProcessor
 class FailOverLoadBalancer
          This FailOverLoadBalancer will failover to use next processor when an exception occurred

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

 class LoadBalancerSupport
          A default base class for a LoadBalancer implementation.
 class QueueLoadBalancer
          A base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)
 class RandomLoadBalancer
          Implements the random load balancing policy
 class RoundRobinLoadBalancer
          Implements the round robin load balancing policy
 class SimpleLoadBalancerSupport
          A default base class for a LoadBalancer implementation.
 class StickyLoadBalancer
          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.
 class TopicLoadBalancer
          A LoadBalancer implementations which sends to all destinations (rather like JMS Topics).
 class WeightedLoadBalancer
           
 class WeightedRandomLoadBalancer
           
 class WeightedRoundRobinLoadBalancer
           
 

Uses of AsyncProcessor in org.apache.camel.processor.validation
 

Classes in org.apache.camel.processor.validation that implement AsyncProcessor
 class ValidatingProcessor
          A processor which validates the XML version of the inbound message body against some schema either in XSD or RelaxNG
 

Uses of AsyncProcessor in org.apache.camel.util
 

Methods in org.apache.camel.util that return AsyncProcessor
static AsyncProcessor AsyncProcessorConverterHelper.convert(Processor value)
           
 

Methods in org.apache.camel.util with parameters of type AsyncProcessor
static void AsyncProcessorHelper.process(AsyncProcessor processor, Exchange exchange)
          Calls the async version of the processor's process method and waits for it to complete before returning.
static boolean AsyncProcessorHelper.process(AsyncProcessor processor, Exchange exchange, AsyncCallback callback)
          Deprecated. should no longer be needed, instead invoke the process method on the AsyncProcessor directly, instead of using this method.
 



Apache Camel