Package | Description |
---|---|
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 | |
org.apache.camel.component.validator |
The Validator Component for validating XML against some schema
|
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.aggregate |
Helper classes for the Aggregator pattern.
|
org.apache.camel.processor.binding |
Helper classes for the Binding concept on Endpoints.
|
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.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.
|
org.apache.camel.util.component |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
boolean |
MethodInvocation.proceed(AsyncCallback callback)
Proceed and invokes the method.
|
boolean |
BeanProducer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
BeanProcessor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
ControlBusProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
DirectProducer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
DirectBlockingProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
DirectVmProducer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
DirectVmProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
DirectVmBlockingProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
LogProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
CollectionProducer.process(Exchange exchange,
AsyncCallback callback)
Deprecated.
|
boolean |
SedaProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
ValidatorProducer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
AsyncCallback |
MDCUnitOfWork.beforeProcess(Processor processor,
Exchange exchange,
AsyncCallback callback) |
AsyncCallback |
DefaultUnitOfWork.beforeProcess(Processor processor,
Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
boolean |
InstrumentationProcessor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
LoadBalancerDefinition.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
RedeliveryErrorHandler.deliverToFailureProcessor(Processor processor,
boolean isDeadLetterChannel,
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,
Iterable<ProcessorExchangePair> pairs,
AsyncCallback callback,
boolean doneSync,
boolean forceExhaust)
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 |
RecipientList.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SetPropertyProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RoutingSlip.process(Exchange exchange,
AsyncCallback callback) |
boolean |
FilterProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
CatchProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RemoveHeaderProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
UnmarshalProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SetBodyProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
ExchangePatternProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
CamelInternalProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
WireTapProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
OnCompletionProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RemovePropertiesProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SamplingThrottler.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SendProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
ChoiceProcessor.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 |
LoopProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
CamelLogger.process(Exchange exchange,
AsyncCallback callback)
Deprecated.
|
boolean |
StreamResequencer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
TransformProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SetHeaderProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
ThroughputLogger.process(Exchange exchange,
AsyncCallback callback) |
boolean |
CamelLogProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RemovePropertyProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RollbackProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
ThrowExceptionProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
InterceptorToAsyncProcessorBridge.process(Exchange exchange,
AsyncCallback callback) |
boolean |
EvaluateExpressionProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
StopProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
Splitter.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SortProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
FinallyProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
Pipeline.process(Exchange exchange,
AsyncCallback callback) |
boolean |
LogProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RedeliveryErrorHandler.process(Exchange exchange,
AsyncCallback callback)
Process the exchange using redelivery error handling.
|
boolean |
DelegateAsyncProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
FatalFallbackErrorHandler.process(Exchange exchange,
AsyncCallback callback) |
boolean |
PollEnricher.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 |
ConvertBodyProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
DelegateSyncProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
ThreadsProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
DelayProcessorSupport.process(Exchange exchange,
AsyncCallback callback) |
boolean |
MulticastProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
TryProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
MarshalProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
RemoveHeadersProcessor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
BatchProcessor.process(Exchange exchange,
AsyncCallback callback)
Deprecated.
Enqueues an exchange for later batch processing.
|
protected boolean |
LoopProcessor.process(Exchange exchange,
AsyncCallback callback,
AtomicInteger index,
AtomicInteger count,
Exchange original) |
protected boolean |
TryProcessor.process(Exchange exchange,
AsyncCallback callback,
Iterator<Processor> processors,
AsyncProcessor processor,
Object lastHandled) |
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 |
Throttler.processDelay(Exchange exchange,
AsyncCallback callback,
long delay) |
protected boolean |
DelayProcessorSupport.processDelay(Exchange exchange,
AsyncCallback callback,
long delay) |
protected boolean |
RoutingSlip.processExchange(Endpoint endpoint,
Exchange exchange,
Exchange original,
AsyncCallback callback,
RoutingSlip.RoutingSlipIterator iter) |
protected boolean |
DelegateAsyncProcessor.processNext(Exchange exchange,
AsyncCallback callback)
Deprecated.
|
boolean |
RecipientList.sendToRecipientList(Exchange exchange,
Object recipientList,
AsyncCallback callback)
Sends the given exchange to the recipient list
|
Modifier and Type | Method and Description |
---|---|
boolean |
AggregateProcessor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
RestBindingProcessor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
IdempotentConsumer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
StreamCachingInterceptor.process(Exchange exchange,
AsyncCallback callback)
Deprecated.
|
boolean |
HandleFaultInterceptor.process(Exchange exchange,
AsyncCallback callback) |
boolean |
TraceInterceptor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
TopicLoadBalancer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
CircuitBreakerLoadBalancer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
QueueLoadBalancer.process(Exchange exchange,
AsyncCallback callback) |
boolean |
SimpleLoadBalancerSupport.process(Exchange exchange,
AsyncCallback callback) |
boolean |
FailOverLoadBalancer.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
ValidatingProcessor.process(Exchange exchange,
AsyncCallback callback) |
Modifier and Type | Method and Description |
---|---|
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. |
Modifier and Type | Method and Description |
---|---|
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. |
Modifier and Type | Method and Description |
---|---|
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. |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractApiProducer.process(Exchange exchange,
AsyncCallback callback) |
Apache Camel