Uses of Interface
org.apache.camel.AsyncCallback

Packages that use AsyncCallback
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.direct The Direct Component which synchronously invokes all the consumers 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.management Camel management 
org.apache.camel.model The JAXB POJOs for the XML Configuration of the routing rules. 
org.apache.camel.processor A collection of Processor implementations which are used to implement the Enterprise Integration Patterns 
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.spi Service Provider Interfaces used internally by the Camel runtime which are plugin strategies. 
org.apache.camel.util Utility classes used by the core of Camel. 
 

Uses of AsyncCallback in org.apache.camel
 

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

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

Methods in org.apache.camel.component.bean with parameters of type AsyncCallback
 Object MethodInvocation.proceed(AsyncCallback callback, AtomicBoolean doneSync)
           
 boolean BeanProcessor.process(Exchange exchange, AsyncCallback callback)
           
 

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

Methods in org.apache.camel.component.direct with parameters of type AsyncCallback
 boolean DirectProducer.process(Exchange exchange, AsyncCallback callback)
           
 

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

Methods in org.apache.camel.component.log with parameters of type AsyncCallback
 boolean LogProducer.process(Exchange exchange, AsyncCallback callback)
           
 

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

Methods in org.apache.camel.component.seda with parameters of type AsyncCallback
 boolean SedaProducer.process(Exchange exchange, AsyncCallback callback)
           
 boolean CollectionProducer.process(Exchange exchange, AsyncCallback callback)
          Deprecated.  
 

Uses of AsyncCallback in org.apache.camel.impl
 

Methods in org.apache.camel.impl that return AsyncCallback
 AsyncCallback MDCUnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
           
 AsyncCallback DefaultUnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
           
 

Methods in org.apache.camel.impl with parameters of type AsyncCallback
 void MDCUnitOfWork.afterProcess(Processor processor, Exchange exchange, AsyncCallback callback, boolean doneSync)
           
 void DefaultUnitOfWork.afterProcess(Processor processor, Exchange exchange, AsyncCallback callback, boolean doneSync)
           
 AsyncCallback MDCUnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
           
 AsyncCallback DefaultUnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
           
 boolean ProducerCache.doInAsyncProducer(Endpoint endpoint, Exchange exchange, ExchangePattern pattern, AsyncCallback callback, AsyncProducerCallback producerCallback)
          Sends an exchange to an endpoint using a supplied callback supporting the asynchronous routing engine.
 

Uses of AsyncCallback in org.apache.camel.management
 

Methods in org.apache.camel.management with parameters of type AsyncCallback
 boolean InstrumentationProcessor.process(Exchange exchange, AsyncCallback callback)
           
 

Uses of AsyncCallback in org.apache.camel.model
 

Methods in org.apache.camel.model with parameters of type AsyncCallback
 boolean LoadBalancerDefinition.process(Exchange exchange, AsyncCallback callback)
           
 

Uses of AsyncCallback in org.apache.camel.processor
 

Methods in org.apache.camel.processor with parameters of type AsyncCallback
protected  boolean RedeliveryErrorHandler.deliverToFailureProcessor(Processor processor, Exchange exchange, RedeliveryErrorHandler.RedeliveryData data, AsyncCallback callback)
          All redelivery attempts failed so move the exchange to the dead letter queue
protected  void MulticastProcessor.doDone(Exchange original, Exchange subExchange, AsyncCallback callback, boolean doneSync, boolean exhaust)
          Common work which must be done when we are done multicasting.
protected  void MulticastProcessor.doProcessParallel(Exchange original, AtomicExchange result, Iterable<ProcessorExchangePair> pairs, boolean streaming, AsyncCallback callback)
           
protected  boolean MulticastProcessor.doProcessSequential(Exchange original, AtomicExchange result, Iterable<ProcessorExchangePair> pairs, AsyncCallback callback)
           
 boolean RoutingSlip.doRoutingSlip(Exchange exchange, Object routingSlip, AsyncCallback callback)
           
 boolean LogProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean SendProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean ChoiceProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean RedeliveryErrorHandler.process(Exchange exchange, AsyncCallback callback)
           
 boolean MulticastProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean DelayProcessorSupport.process(Exchange exchange, AsyncCallback callback)
           
 boolean RoutingSlip.process(Exchange exchange, AsyncCallback callback)
           
 boolean DelegateAsyncProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean TryProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean RecipientList.process(Exchange exchange, AsyncCallback callback)
           
 boolean ThreadsProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean Splitter.process(Exchange exchange, AsyncCallback callback)
           
 boolean SamplingThrottler.process(Exchange exchange, AsyncCallback callback)
           
 boolean EvaluateExpressionProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean LoopProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean Enricher.process(Exchange exchange, AsyncCallback callback)
          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.
 boolean WireTapProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean InterceptorToAsyncProcessorBridge.process(Exchange exchange, AsyncCallback callback)
           
 boolean UnitOfWorkProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean SubUnitOfWorkProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean Pipeline.process(Exchange exchange, AsyncCallback callback)
           
 boolean FilterProcessor.process(Exchange exchange, AsyncCallback callback)
           
 boolean RoutePolicyProcessor.process(Exchange exchange, AsyncCallback callback)
           
protected  boolean TryProcessor.process(Exchange exchange, AsyncCallback callback, AsyncProcessor processor, Iterator<AsyncProcessor> processors)
           
protected  boolean LoopProcessor.process(Exchange exchange, AsyncCallback callback, AtomicInteger index, AtomicInteger count)
           
protected  boolean UnitOfWorkProcessor.processAsync(Exchange exchange, AsyncCallback callback, UnitOfWork uow)
           
protected  void RedeliveryErrorHandler.processAsyncErrorHandler(Exchange exchange, AsyncCallback callback, RedeliveryErrorHandler.RedeliveryData data)
          This logic is only executed if we have to retry redelivery asynchronously, which have to be done from the callback.
protected  boolean RedeliveryErrorHandler.processErrorHandler(Exchange exchange, AsyncCallback callback, RedeliveryErrorHandler.RedeliveryData data)
          Process the exchange using redelivery error handling.
protected  boolean RoutingSlip.processExchange(Endpoint endpoint, Exchange exchange, Exchange original, AsyncCallback callback, RoutingSlip.RoutingSlipIterator iter)
           
protected  boolean RouteInflightRepositoryProcessor.processNext(Exchange exchange, AsyncCallback callback)
           
protected  boolean DelegateAsyncProcessor.processNext(Exchange exchange, AsyncCallback callback)
           
protected  boolean RouteContextProcessor.processNext(Exchange exchange, AsyncCallback callback)
           
protected  boolean FatalFallbackErrorHandler.processNext(Exchange exchange, AsyncCallback callback)
           
protected  boolean UnitOfWorkProcessor.processSync(Exchange exchange, AsyncCallback callback, UnitOfWork uow)
           
 boolean RecipientList.sendToRecipientList(Exchange exchange, Object recipientList, AsyncCallback callback)
          Sends the given exchange to the recipient list
 

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

Methods in org.apache.camel.processor.idempotent with parameters of type AsyncCallback
 boolean IdempotentConsumer.process(Exchange exchange, AsyncCallback callback)
           
 

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

Methods in org.apache.camel.processor.interceptor with parameters of type AsyncCallback
 boolean StreamCachingInterceptor.process(Exchange exchange, AsyncCallback callback)
           
 boolean TraceInterceptor.process(Exchange exchange, AsyncCallback callback)
           
 boolean DefaultChannel.process(Exchange exchange, AsyncCallback callback)
           
 boolean HandleFaultInterceptor.process(Exchange exchange, AsyncCallback callback)
           
 

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

Methods in org.apache.camel.processor.loadbalancer with parameters of type AsyncCallback
 boolean SimpleLoadBalancerSupport.process(Exchange exchange, AsyncCallback callback)
           
 boolean QueueLoadBalancer.process(Exchange exchange, AsyncCallback callback)
           
 boolean FailOverLoadBalancer.process(Exchange exchange, AsyncCallback callback)
           
 boolean TopicLoadBalancer.process(Exchange exchange, AsyncCallback callback)
           
 

Uses of AsyncCallback in org.apache.camel.spi
 

Methods in org.apache.camel.spi that return AsyncCallback
 AsyncCallback UnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
          Strategy for optional work to be execute before processing

For example the MDCUnitOfWork leverages this to ensure MDC is handled correctly during routing exchanges using the asynchronous routing engine.

 

Methods in org.apache.camel.spi with parameters of type AsyncCallback
 void UnitOfWork.afterProcess(Processor processor, Exchange exchange, AsyncCallback callback, boolean doneSync)
          Strategy for optional work to be executed after the processing
 AsyncCallback UnitOfWork.beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
          Strategy for optional work to be execute before processing

For example the MDCUnitOfWork leverages this to ensure MDC is handled correctly during routing exchanges using the asynchronous routing engine.

 

Uses of AsyncCallback in org.apache.camel.util
 

Methods in org.apache.camel.util with parameters of type AsyncCallback
static boolean AsyncProcessorHelper.process(AsyncProcessor processor, Exchange exchange, AsyncCallback callback)
          Calls the async version of the processor's process method.
 



Apache CAMEL