|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
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.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.fabric | |
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.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.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 Processor s 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.direct |
---|
Classes in org.apache.camel.component.direct that implement AsyncProcessor | |
---|---|
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 |
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.fabric |
---|
Classes in org.apache.camel.fabric that implement AsyncProcessor | |
---|---|
class |
FabricTraceProcessor
|
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 Exchange s 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 |
CatchProcessor
A processor which catches exceptions. |
class |
ChildUnitOfWorkProcessor
An UnitOfWorkProcessor that creates a child UnitOfWork that is
associated to a parent UnitOfWork . |
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 |
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 |
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 |
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 |
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 |
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 |
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 |
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 |
RouteContextProcessor
This processor tracks the current RouteContext while processing the Exchange . |
class |
RouteInflightRepositoryProcessor
This processor tracks the current RouteContext while processing the Exchange . |
class |
RoutePolicyProcessor
Processor which instruments the RoutePolicy . |
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 |
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 |
SubUnitOfWorkProcessor
A processor that processes the processor in a SubUnitOfWork context. |
class |
ThreadsProcessor
Threads processor that leverage a thread pool for continue processing the Exchange s
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 |
TryProcessor
Implements try/catch/finally type processing |
class |
UnitOfWorkProcessor
Ensures the Exchange is routed under the boundaries of an UnitOfWork . |
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 |
TryProcessor.tryProcessor
|
Methods in org.apache.camel.processor that return AsyncProcessor | |
---|---|
AsyncProcessor |
DelegateAsyncProcessor.getProcessor()
|
Methods in org.apache.camel.processor that return types with arguments of type AsyncProcessor | |
---|---|
protected Collection<AsyncProcessor> |
TryProcessor.getProcessors()
|
Methods in org.apache.camel.processor with parameters of type AsyncProcessor | |
---|---|
protected boolean |
TryProcessor.process(Exchange exchange,
AsyncCallback callback,
AsyncProcessor processor,
Iterator<AsyncProcessor> processors)
|
void |
DelegateAsyncProcessor.setProcessor(AsyncProcessor processor)
|
Method parameters in org.apache.camel.processor with type arguments of type AsyncProcessor | |
---|---|
protected boolean |
TryProcessor.continueRouting(Iterator<AsyncProcessor> it,
Exchange exchange)
|
protected boolean |
TryProcessor.process(Exchange exchange,
AsyncCallback callback,
AsyncProcessor processor,
Iterator<AsyncProcessor> processors)
|
Constructors in org.apache.camel.processor with parameters of type AsyncProcessor | |
---|---|
ChildUnitOfWorkProcessor(UnitOfWork parent,
AsyncProcessor processor)
|
|
ChildUnitOfWorkProcessor(UnitOfWork parent,
RouteContext routeContext,
AsyncProcessor processor)
|
|
DelegateAsyncProcessor(AsyncProcessor processor)
|
|
InterceptorToAsyncProcessorBridge(Processor interceptor,
AsyncProcessor target)
Constructs the bridge |
|
SubUnitOfWorkProcessor(AsyncProcessor processor)
|
|
SubUnitOfWorkProcessor(RouteContext routeContext,
AsyncProcessor processor)
|
|
UnitOfWorkProcessor(AsyncProcessor processor)
|
|
UnitOfWorkProcessor(RouteContext routeContext,
AsyncProcessor processor)
|
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
An interceptor for delaying routes. |
class |
HandleFaultInterceptor
|
class |
StreamCachingInterceptor
An interceptor that converts streams messages into a re-readable format by wrapping the stream into a StreamCache . |
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.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)
Calls the async version of the processor's process method. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |