Uses of Interface
org.apache.camel.Exchange
-
Packages that use Exchange Package Description org.apache.camel The core Camel API.org.apache.camel.cloud Camel cloudorg.apache.camel.spi Service Provider Interfaces used by the Camel runtime which are plugin strategies. -
-
Uses of Exchange in org.apache.camel
Subinterfaces of Exchange in org.apache.camel Modifier and Type Interface Description interface
ExtendedExchange
ExtendedExchange
which contains the methods and APIs that are not intended for Camel end users but used internally by Camel for optimization purposes, SPI, custom components, or more advanced used-cases with Camel.interface
PooledExchange
PooledExchange
which contains the methods and APIs that are not intended for Camel end users but used internally by Camel for optimizing memory footprint by reusing exchanges created byConsumer
s viaExchangeFactory
.Methods in org.apache.camel with type parameters of type Exchange Modifier and Type Method Description <T extends Exchange>
TExchange. adapt(Class<T> type)
Adapts thisExchange
to the specialized type.Methods in org.apache.camel that return Exchange Modifier and Type Method Description Exchange
AggregationStrategy. aggregate(Exchange oldExchange, Exchange newExchange)
Aggregates an old and new exchange together to create a single combined exchangedefault Exchange
AggregationStrategy. aggregate(Exchange oldExchange, Exchange newExchange, Exchange inputExchange)
Aggregates an old and new exchange together to create a single combined exchange.Exchange
Exchange. copy()
Creates a copy of the current message exchange so that it can be forwarded to another destinationExchange
Consumer. createExchange(boolean autoRelease)
Creates anExchange
that was consumed.Exchange
Endpoint. createExchange()
Create a new exchange for communicating with this endpoint.Exchange
Endpoint. createExchange(ExchangePattern pattern)
Create a new exchange for communicating with this endpoint with the specifiedExchangePattern
such as whether its going to be anExchangePattern.InOnly
orExchangePattern.InOut
exchangeExchange
CamelExchangeException. getExchange()
Returns the exchange which caused the exceptionExchange
ExpectedBodyTypeException. getExchange()
Exchange
ExpressionEvaluationException. getExchange()
Exchange
Message. getExchange()
Returns the exchange this message is related toExchange
RuntimeExchangeException. getExchange()
Returns the exchange which caused the exceptionExchange
ConsumerTemplate. receive(String endpointUri)
Receives from the endpoint, waiting until there is a responseExchange
ConsumerTemplate. receive(String endpointUri, long timeout)
Receives from the endpoint, waiting until there is a response or the timeout occursExchange
ConsumerTemplate. receive(Endpoint endpoint)
Receives from the endpoint, waiting until there is a response.Exchange
ConsumerTemplate. receive(Endpoint endpoint, long timeout)
Receives from the endpoint, waiting until there is a response or the timeout occursExchange
PollingConsumer. receive()
Waits until a message is available and then returns it.Exchange
PollingConsumer. receive(long timeout)
Attempts to receive a message exchange, waiting up to the given timeout to expire if a message is not yet available.Exchange
ConsumerTemplate. receiveNoWait(String endpointUri)
Receives from the endpoint, not waiting for a response if non exists.Exchange
ConsumerTemplate. receiveNoWait(Endpoint endpoint)
Receives from the endpoint, not waiting for a response if non exists.Exchange
PollingConsumer. receiveNoWait()
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.Exchange
ProducerTemplate. request(String endpointUri, Processor processor)
Sends an exchange to an endpoint using a supplied processor Uses anExchangePattern.InOut
message exchange pattern.Exchange
ProducerTemplate. request(Endpoint endpoint, Processor processor)
Sends an exchange to an endpoint using a supplied processor Uses anExchangePattern.InOut
message exchange pattern.Exchange
FluentProducerTemplate. send()
Send to an endpoint (InOnly)Exchange
ProducerTemplate. send(String endpointUri, Exchange exchange)
Sends the exchange to the given endpoint
Exchange
ProducerTemplate. send(String endpointUri, ExchangePattern pattern, Processor processor)
Sends an exchange to an endpoint using a supplied processor
Exchange
ProducerTemplate. send(String endpointUri, Processor processor)
Sends an exchange to an endpoint using a supplied processor
Exchange
ProducerTemplate. send(Endpoint endpoint, Exchange exchange)
Sends the exchange to the given endpoint
Exchange
ProducerTemplate. send(Endpoint endpoint, ExchangePattern pattern, Processor processor)
Sends an exchange to an endpoint using a supplied processor
Exchange
ProducerTemplate. send(Endpoint endpoint, ExchangePattern pattern, Processor processor, Processor resultProcessor)
Sends an exchange to an endpoint using a supplied processor
Exchange
ProducerTemplate. send(Endpoint endpoint, Processor processor)
Sends an exchange to an endpoint using a supplied processor
Exchange
ProducerTemplate. send(Exchange exchange)
Sends the exchange to the default endpoint
Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange usinggetException()
.Exchange
ProducerTemplate. send(Processor processor)
Sends an exchange to the default endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange usinggetException()
.Methods in org.apache.camel that return types with arguments of type Exchange Modifier and Type Method Description CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(String endpointUri, Exchange exchange, Synchronization onCompletion)
Deprecated.CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(String endpointUri, Processor processor, Synchronization onCompletion)
Deprecated.CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(Endpoint endpoint, Exchange exchange, Synchronization onCompletion)
Deprecated.CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(Endpoint endpoint, Processor processor, Synchronization onCompletion)
Deprecated.Future<Exchange>
FluentProducerTemplate. asyncSend()
Sends asynchronously to the given endpoint (InOnly).CompletableFuture<Exchange>
ProducerTemplate. asyncSend(String endpointUri, Exchange exchange)
Sends an asynchronous exchange to the given endpoint.CompletableFuture<Exchange>
ProducerTemplate. asyncSend(String endpointUri, Processor processor)
Sends an asynchronous exchange to the given endpoint.CompletableFuture<Exchange>
ProducerTemplate. asyncSend(Endpoint endpoint, Exchange exchange)
Sends an asynchronous exchange to the given endpoint.CompletableFuture<Exchange>
ProducerTemplate. asyncSend(Endpoint endpoint, Processor processor)
Sends an asynchronous exchange to the given endpoint.CompletableFuture<Exchange>
AsyncProcessor. processAsync(Exchange exchange)
Methods in org.apache.camel with parameters of type Exchange Modifier and Type Method Description Exchange
AggregationStrategy. aggregate(Exchange oldExchange, Exchange newExchange)
Aggregates an old and new exchange together to create a single combined exchangedefault Exchange
AggregationStrategy. aggregate(Exchange oldExchange, Exchange newExchange, Exchange inputExchange)
Aggregates an old and new exchange together to create a single combined exchange.CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(String endpointUri, Exchange exchange, Synchronization onCompletion)
Deprecated.CompletableFuture<Exchange>
ProducerTemplate. asyncCallback(Endpoint endpoint, Exchange exchange, Synchronization onCompletion)
Deprecated.CompletableFuture<Exchange>
ProducerTemplate. asyncSend(String endpointUri, Exchange exchange)
Sends an asynchronous exchange to the given endpoint.CompletableFuture<Exchange>
ProducerTemplate. asyncSend(Endpoint endpoint, Exchange exchange)
Sends an asynchronous exchange to the given endpoint.void
Endpoint. configureExchange(Exchange exchange)
Configures a newly createdExchange
.<T> T
TypeConverter. convertTo(Class<T> type, Exchange exchange, Object value)
Converts the value to the specified type in the context of an exchangeStreamCache
StreamCache. copy(Exchange exchange)
Create a copy of the stream.void
ExtendedExchange. copyInternalProperties(Exchange target)
To copy the internal properties from this exchange to the target exchangestatic String
CamelExchangeException. createExceptionMessage(String message, Exchange exchange, Throwable cause)
Creates an exception message with the provided details.protected static String
RuntimeExchangeException. createMessage(String message, Exchange exchange)
default AsyncCallback
Consumer. defaultConsumerCallback(Exchange exchange, boolean autoRelease)
The default callback to use with the consumer when calling the processor using asynchronous routing.void
ConsumerTemplate. doneUoW(Exchange exchange)
<T> T
Expression. evaluate(Exchange exchange, Class<T> type)
Returns the value of the expression on the given exchangevoid
ExtendedExchange. handoverCompletions(Exchange target)
Handover all the on completions from this exchange to the target exchange.<T> T
TypeConverter. mandatoryConvertTo(Class<T> type, Exchange exchange, Object value)
Converts the value to the specified type in the context of an exchangeboolean
Predicate. matches(Exchange exchange)
Evaluates the predicate on the message exchange and returns true if this exchange matches the predicateString
BinaryPredicate. matchesReturningFailureMessage(Exchange exchange)
Evaluates the predicate on the message exchange and returns null if this exchange matches the predicate.default void
AggregationStrategy. onCompletion(Exchange exchange)
The aggregatedExchange
has completed Important: This method must not throw any exceptions.void
PooledExchange.OnDoneTask. onDone(Exchange exchange)
default void
AggregationStrategy. onOptimisticLockFailure(Exchange oldExchange, Exchange newExchange)
Callback when the aggregatedExchange
fails to add in theOptimisticLockingAggregationRepository
because of anOptimisticLockingAggregationRepository.OptimisticLockingException
.default boolean
AggregationStrategy. preComplete(Exchange oldExchange, Exchange newExchange)
Determines if the aggregation should complete the current group, and start a new group, or the aggregation should continue using the current group.boolean
AsyncProcessor. process(Exchange exchange, AsyncCallback callback)
Processes the message exchange.void
Processor. process(Exchange exchange)
Processes the message exchangeCompletableFuture<Exchange>
AsyncProcessor. processAsync(Exchange exchange)
protected static String
NoSuchHeaderException. reason(Exchange exchange, String propertyName)
protected static String
NoSuchPropertyException. reason(Exchange exchange, String propertyName)
void
Consumer. releaseExchange(Exchange exchange, boolean autoRelease)
Releases theExchange
when its completed processing and no longer needed.Exchange
ProducerTemplate. send(String endpointUri, Exchange exchange)
Sends the exchange to the given endpoint
Exchange
ProducerTemplate. send(Endpoint endpoint, Exchange exchange)
Sends the exchange to the given endpoint
Exchange
ProducerTemplate. send(Exchange exchange)
Sends the exchange to the default endpoint
Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange usinggetException()
.default void
AggregationStrategy. timeout(Exchange exchange, int index, int total, long timeout)
A timeout occurred.<T> T
TypeConverter. tryConvertTo(Class<T> type, Exchange exchange, Object value)
Tries to convert the value to the specified type in the context of an exchange, returning null if not possible to convert.FluentProducerTemplate
FluentProducerTemplate. withExchange(Exchange exchange)
Set the exchange to use for send.static CamelExecutionException
CamelExecutionException. wrapCamelExecutionException(Exchange exchange, Throwable e)
Wraps the caused exception in aCamelExecutionException
if its not already such an exception.Method parameters in org.apache.camel with type arguments of type Exchange Modifier and Type Method Description FluentProducerTemplate
FluentProducerTemplate. withExchange(Supplier<Exchange> exchangeSupplier)
Set the exchangeSupplier which will be invoke to get the exchange to be used for send. -
Uses of Exchange in org.apache.camel.cloud
Methods in org.apache.camel.cloud with parameters of type Exchange Modifier and Type Method Description List<ServiceDefinition>
ServiceFilter. apply(Exchange exchange, List<ServiceDefinition> services)
Chooses service candidates to use<T> T
ServiceLoadBalancer. process(Exchange exchange, String serviceName, ServiceLoadBalancerFunction<T> function)
-
Uses of Exchange in org.apache.camel.spi
Methods in org.apache.camel.spi that return Exchange Modifier and Type Method Description Exchange
AggregationRepository. add(CamelContext camelContext, String key, Exchange exchange)
Add the givenExchange
under the correlation key.Exchange
OptimisticLockingAggregationRepository. add(CamelContext camelContext, String key, Exchange oldExchange, Exchange newExchange)
Add the givenExchange
under the correlation key.Exchange
ExchangeFactory. create(boolean autoRelease)
Gets a newExchange
Exchange
ExchangeFactory. create(Endpoint fromEndpoint, boolean autoRelease)
Gets a newExchange
Exchange
ProcessorExchangeFactory. create(Endpoint fromEndpoint, ExchangePattern exchangePattern)
Gets a newExchange
Exchange
ProcessorExchangeFactory. createCopy(Exchange exchange)
Gets a copy of the givenExchange
Exchange
ProcessorExchangeFactory. createCorrelatedCopy(Exchange exchange, boolean handover)
Gets a copy of the givenExchange
the the copy is correlated to the sourceExchange
AggregationRepository. get(CamelContext camelContext, String key)
Gets the given exchange with the correlation keyExchange
ClaimCheckRepository. get(String key)
Gets the exchange from the repository.Exchange
ClaimCheckRepository. getAndRemove(String key)
Gets and removes the exchange from the repository.Exchange
AsyncProcessorAwaitManager.AwaitThread. getExchange()
The exchange being processed by the other thread.Exchange
CamelEvent.ExchangeEvent. getExchange()
Exchange
InflightRepository.InflightExchange. getExchange()
The exchange being inflightExchange
ClaimCheckRepository. pop()
Pops the repository and returns the latest.Exchange
ConsumerCache. receive(Endpoint endpoint)
Waits until a message is available and then returns it.Exchange
ConsumerCache. receive(Endpoint endpoint, long timeout)
Attempts to receive a message exchange, waiting up to the given timeout to expire if a message is not yet available.Exchange
ConsumerCache. receiveNoWait(Endpoint endpoint)
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.Exchange
RecoverableAggregationRepository. recover(CamelContext camelContext, String exchangeId)
Recovers the exchange with the given exchange idExchange
ProducerCache. send(Endpoint endpoint, Exchange exchange, Processor resultProcessor)
Sends the exchange to the given endpoint.Methods in org.apache.camel.spi that return types with arguments of type Exchange Modifier and Type Method Description CompletableFuture<Exchange>
ProducerCache. asyncSendExchange(Endpoint endpoint, ExchangePattern pattern, Processor processor, Processor resultProcessor, Exchange exchange, CompletableFuture<Exchange> future)
Asynchronously sends an exchange to an endpoint using a suppliedProcessor
to populate the exchangeList<Exchange>
BrowsableEndpoint. getExchanges()
Return the exchanges available on this endpointMethods in org.apache.camel.spi with parameters of type Exchange Modifier and Type Method Description Exchange
AggregationRepository. add(CamelContext camelContext, String key, Exchange exchange)
Add the givenExchange
under the correlation key.boolean
ClaimCheckRepository. add(String key, Exchange exchange)
Adds the exchange to the repository.default boolean
IdempotentRepository. add(Exchange exchange, String key)
Adds the key to the repository.void
InflightRepository. add(Exchange exchange)
Adds the exchange to the inflight registry to the total countervoid
InflightRepository. add(Exchange exchange, String routeId)
Adds the exchange to the inflight registry associated to the given routeExchange
OptimisticLockingAggregationRepository. add(CamelContext camelContext, String key, Exchange oldExchange, Exchange newExchange)
Add the givenExchange
under the correlation key.void
CamelInternalProcessorAdvice. after(Exchange exchange, T data)
Callback executed after processing a step in the route.void
ManagementInterceptStrategy.InstrumentationProcessor. after(Exchange exchange, T data)
void
Breakpoint. afterProcess(Exchange exchange, Processor processor, NamedNode definition, long timeTaken)
Callback invoked when the breakpoint was hit and theExchange
has been processed (after).boolean
Debugger. afterProcess(Exchange exchange, Processor processor, NamedNode definition, long timeTaken)
Callback invoked when anExchange
has been processed which allows implementators to notify breakpoints.void
UnitOfWork. afterProcess(Processor processor, Exchange exchange, AsyncCallback callback, boolean doneSync)
Strategy for work to be executed after the processingvoid
UnitOfWork. afterRoute(Exchange exchange, Route route)
Invoked when this unit of work is done being routed by the given route.boolean
HeaderFilterStrategy. applyFilterToCamelHeaders(String headerName, Object headerValue, Exchange exchange)
Applies filtering logic to Camel Message header that is going to be copied to target message such as CXF and JMS message.boolean
HeaderFilterStrategy. applyFilterToExternalHeaders(String headerName, Object headerValue, Exchange exchange)
Applies filtering logic to an external message header such as CXF and JMS message that is going to be copied to Camel message header.CompletableFuture<Exchange>
ProducerCache. asyncSendExchange(Endpoint endpoint, ExchangePattern pattern, Processor processor, Processor resultProcessor, Exchange exchange, CompletableFuture<Exchange> future)
Asynchronously sends an exchange to an endpoint using a suppliedProcessor
to populate the exchangeT
CamelInternalProcessorAdvice. before(Exchange exchange)
Callback executed before processing a step in the route.T
ManagementInterceptStrategy.InstrumentationProcessor. before(Exchange exchange)
void
Breakpoint. beforeProcess(Exchange exchange, Processor processor, NamedNode definition)
Callback invoked when the breakpoint was hit and theExchange
is about to be processed (before).boolean
Debugger. beforeProcess(Exchange exchange, Processor processor, NamedNode definition)
Callback invoked when anExchange
is about to be processed which allows implementators to notify breakpoints.AsyncCallback
UnitOfWork. beforeProcess(Processor processor, Exchange exchange, AsyncCallback callback)
Strategy for work to be executed before processing.void
UnitOfWork. beforeRoute(Exchange exchange, Route route)
Invoked when this unit of work is about to be routed by the given route.StreamCache
StreamCachingStrategy. cache(Exchange exchange)
Caches the body aas aStreamCache
.default boolean
IdempotentRepository. confirm(Exchange exchange, String key)
Confirms the key, after the exchange has been processed successfully.default boolean
IdempotentRepository. contains(Exchange exchange, String key)
Returns true if this repository contains the specified element.<T> T
BulkTypeConverters. convertTo(Class<?> from, Class<T> to, Exchange exchange, Object value)
Converts the value to the specified type in the context of an exchangedefault <T> T
BulkTypeConverters. convertTo(Class<T> type, Exchange exchange, Object value)
UnitOfWork
UnitOfWork. createChildUnitOfWork(Exchange childExchange)
Create a child unit of work, which is associated to this unit of work as its parent.Exchange
ProcessorExchangeFactory. createCopy(Exchange exchange)
Gets a copy of the givenExchange
Exchange
ProcessorExchangeFactory. createCorrelatedCopy(Exchange exchange, boolean handover)
Gets a copy of the givenExchange
the the copy is correlated to the sourceCamelEvent
EventFactory. createExchangeCompletedEvent(Exchange exchange)
Creates anCamelEvent
when anExchange
has been completed successfullyCamelEvent
EventFactory. createExchangeCreatedEvent(Exchange exchange)
Creates anCamelEvent
when anExchange
has been createdCamelEvent
EventFactory. createExchangeFailedEvent(Exchange exchange)
Creates anCamelEvent
when anExchange
has failedCamelEvent
EventFactory. createExchangeFailureHandledEvent(Exchange exchange, Processor failureHandler, boolean deadLetterChannel, String deadLetterUri)
Creates anCamelEvent
when anExchange
has failed but was handled by the Camel error handlers such as an dead letter channel, or a doTry ..CamelEvent
EventFactory. createExchangeFailureHandlingEvent(Exchange exchange, Processor failureHandler, boolean deadLetterChannel, String deadLetterUri)
Creates anCamelEvent
when anExchange
has failed but is being handled by the Camel error handlers such as an dead letter channel, or a doTry ..CamelEvent
EventFactory. createExchangeRedeliveryEvent(Exchange exchange, int attempt)
Creates anCamelEvent
when anExchange
is about to be redeliveredCamelEvent
EventFactory. createExchangeSendingEvent(Exchange exchange, Endpoint endpoint)
Creates anCamelEvent
when anExchange
is about to be sent to the endpoint (eg before).CamelEvent
EventFactory. createExchangeSentEvent(Exchange exchange, Endpoint endpoint, long timeTaken)
Creates anCamelEvent
when anExchange
has completely been sent to the endpoint (eg after).Processor
SendDynamicAware. createPostProcessor(Exchange exchange, SendDynamicAware.DynamicAwareEntry entry)
Creates an optional postProcessor
that will be executed afterwards when the message has been sent dynamic.Processor
SendDynamicAware. createPreProcessor(Exchange exchange, SendDynamicAware.DynamicAwareEntry entry)
CamelEvent
EventFactory. createStepCompletedEvent(Exchange exchange, String stepId)
Creates anCamelEvent
when a step has been completed successfullyCamelEvent
EventFactory. createStepFailedEvent(Exchange exchange, String stepId)
Creates anCamelEvent
when a step has failedCamelEvent
EventFactory. createStepStartedEvent(Exchange exchange, String stepId)
Creates anCamelEvent
when a step has been startedUnitOfWork
UnitOfWorkFactory. createUnitOfWork(Exchange exchange)
Creates a newUnitOfWork
boolean
ProducerCache.AsyncProducerCallback. doInAsyncProducer(AsyncProducer asyncProducer, Exchange exchange, AsyncCallback callback)
Performs operation on the given producer to send the given exchange.boolean
ProducerCache. doInAsyncProducer(Endpoint endpoint, Exchange exchange, AsyncCallback callback, ProducerCache.AsyncProducerCallback producerCallback)
Sends an exchange to an endpoint using a supplied callback supporting the asynchronous routing engine.void
UnitOfWork. done(Exchange exchange)
Invoked when this unit of work has been completed, whether it has failed or completedString
ExchangeFormatter. format(Exchange exchange)
Generates a string representation of the exchangevoid
ExceptionHandler. handleException(String message, Exchange exchange, Throwable exception)
Handles the given exceptionvoid
UnitOfWork. handoverSynchronization(Exchange target)
Handover all the registered synchronizations to the targetExchange
.void
UnitOfWork. handoverSynchronization(Exchange target, Predicate<Synchronization> filter)
Handover all the registered synchronizations to the targetExchange
.void
AsyncProcessorAwaitManager. interrupt(Exchange exchange)
To interrupt an exchange which may seem as stuck, to force the exchange to continue, allowing any blocking thread to be released.Object
InvokeOnHeaderStrategy. invoke(Object target, String key, Exchange exchange, AsyncCallback callback)
Invoke the method based on the header keydefault <T> T
BulkTypeConverters. mandatoryConvertTo(Class<?> from, Class<T> to, Exchange exchange, Object value)
Converts the value to the specified type in the context of an exchangedefault <T> T
BulkTypeConverters. mandatoryConvertTo(Class<T> type, Exchange exchange, Object value)
void
DataFormat. marshal(Exchange exchange, Object graph, OutputStream stream)
Marshals the object to the given Stream.boolean
Condition. matchEvent(Exchange exchange, CamelEvent.ExchangeEvent event)
Does the condition matchboolean
Condition. matchProcess(Exchange exchange, Processor processor, NamedNode definition)
Does the condition matchMessageHistory
MessageHistoryFactory. newMessageHistory(String routeId, NamedNode node, long timestamp, Exchange exchange)
Creates a newMessageHistory
void
NotifyBuilderMatcher. notifyBuilderOnExchange(Exchange exchange)
When an exchange was receivedvoid
SynchronizationRouteAware. onAfterRoute(Route route, Exchange exchange)
Invoked after theExchange
has been routed by the given route.void
SynchronizationRouteAware. onBeforeRoute(Route route, Exchange exchange)
Invoked before theExchange
is being routed by the given route.void
Synchronization. onComplete(Exchange exchange)
Called when the processing of the message exchange is completevoid
Breakpoint. onEvent(Exchange exchange, CamelEvent.ExchangeEvent event, NamedNode definition)
boolean
Debugger. onEvent(Exchange exchange, CamelEvent.ExchangeEvent event)
Callback invoked when anExchange
is being processed which allows implementators to notify breakpoints.void
RoutePolicy. onExchangeBegin(Route route, Exchange exchange)
void
RoutePolicy. onExchangeDone(Route route, Exchange exchange)
void
Synchronization. onFailure(Exchange exchange)
Called when the processing of the message exchange has failed for some reason.String
LogListener. onLog(Exchange exchange, CamelLogger camelLogger, String message)
Invoked right before Log component or Log EIP logs.boolean
UnitOfWork. onPrepare(Exchange exchange)
Prepares this unit of work with the given inputExchange
SendDynamicAware.DynamicAwareEntry
SendDynamicAware. prepare(Exchange exchange, String uri, String originalUri)
Prepares for using optimised dynamic to by parsing the uri and returning an entry of details that are used for creating the pre and post processors, and the static uri.void
AsyncProcessorAwaitManager. process(AsyncProcessor processor, Exchange exchange)
Process the given exchange sychronously.default void
SharedInternalProcessor. process(Exchange exchange)
boolean
SharedInternalProcessor. process(Exchange exchange, AsyncCallback originalCallback, AsyncProcessor processor, Processor resultProcessor)
Asynchronous APIvoid
SharedInternalProcessor. process(Exchange exchange, AsyncProcessor processor, Processor resultProcessor)
Synchronous APIvoid
ClaimCheckRepository. push(Exchange exchange)
Pushes the exchange on top of the repository.default boolean
ExchangeFactory. release(Exchange exchange)
Releases the exchange back into the poolboolean
ProcessorExchangeFactory. release(Exchange exchange)
Releases the exchange back into the poolvoid
AggregationRepository. remove(CamelContext camelContext, String key, Exchange exchange)
Removes the exchange with the given correlation key, which should happen when anExchange
is completeddefault boolean
IdempotentRepository. remove(Exchange exchange, String key)
Removes the key from the repository.void
InflightRepository. remove(Exchange exchange)
Removes the exchange from the inflight registry to the total countervoid
InflightRepository. remove(Exchange exchange, String routeId)
Removes the exchange from the inflight registry removing association to the given routevoid
OptimisticLockingAggregationRepository. remove(CamelContext camelContext, String key, Exchange exchange)
Removes the given Exchange when both the supplied key and Exchange are present in the repository.String
SendDynamicAware. resolveStaticUri(Exchange exchange, SendDynamicAware.DynamicAwareEntry entry)
Exchange
ProducerCache. send(Endpoint endpoint, Exchange exchange, Processor resultProcessor)
Sends the exchange to the given endpoint.void
Tracer. traceAfterNode(NamedNode node, Exchange exchange)
Trace after the given nodevoid
Tracer. traceAfterRoute(Route route, Exchange exchange)
Trace after the route (eg output from route)void
Tracer. traceBeforeNode(NamedNode node, Exchange exchange)
Trace before the given nodevoid
Tracer. traceBeforeRoute(NamedRoute route, Exchange exchange)
Trace before the route (eg input to route)default <T> T
BulkTypeConverters. tryConvertTo(Class<?> from, Class<T> to, Exchange exchange, Object value)
Tries to convert the value to the specified type, returning null if not possible to convert.default <T> T
BulkTypeConverters. tryConvertTo(Class<T> type, Exchange exchange, Object value)
Object
DataFormat. unmarshal(Exchange exchange, InputStream stream)
Unmarshals the given stream into an object.Method parameters in org.apache.camel.spi with type arguments of type Exchange Modifier and Type Method Description CompletableFuture<Exchange>
ProducerCache. asyncSendExchange(Endpoint endpoint, ExchangePattern pattern, Processor processor, Processor resultProcessor, Exchange exchange, CompletableFuture<Exchange> future)
Asynchronously sends an exchange to an endpoint using a suppliedProcessor
to populate the exchange
-