public class TemporaryQueueReplyManager extends ReplyManagerSupport
ReplyManager
when using temporary queues.camelContext, correlation, endpoint, executorService, listenerContainer, replyTo, replyToLatch, replyToTimeout
Constructor and Description |
---|
TemporaryQueueReplyManager(org.apache.camel.CamelContext camelContext) |
Modifier and Type | Method and Description |
---|---|
protected com.rabbitmq.client.Connection |
createListenerContainer() |
protected ReplyHandler |
createReplyHandler(ReplyManager replyManager,
org.apache.camel.Exchange exchange,
org.apache.camel.AsyncCallback callback,
String originalCorrelationId,
String correlationId,
long requestTimeout) |
protected void |
doStop() |
protected void |
handleReplyMessage(String correlationID,
com.rabbitmq.client.AMQP.BasicProperties properties,
byte[] message) |
void |
updateCorrelationId(String correlationId,
String newCorrelationId,
long requestTimeout)
Updates the correlation id to the new correlation id.
|
cancelCorrelationId, doStart, getReplyTo, onMessage, processReply, registerReply, setEndpoint, setReplyTo, setScheduledExecutorService, waitForProvisionCorrelationToBeUpdated
build, doBuild, doFail, doInit, doLifecycleChange, doResume, doShutdown, doSuspend, fail, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
public TemporaryQueueReplyManager(org.apache.camel.CamelContext camelContext)
protected ReplyHandler createReplyHandler(ReplyManager replyManager, org.apache.camel.Exchange exchange, org.apache.camel.AsyncCallback callback, String originalCorrelationId, String correlationId, long requestTimeout)
createReplyHandler
in class ReplyManagerSupport
public void updateCorrelationId(String correlationId, String newCorrelationId, long requestTimeout)
ReplyManager
correlationId
- the provisional correlation idnewCorrelationId
- the real correlation idrequestTimeout
- the timeoutprotected void handleReplyMessage(String correlationID, com.rabbitmq.client.AMQP.BasicProperties properties, byte[] message)
handleReplyMessage
in class ReplyManagerSupport
protected com.rabbitmq.client.Connection createListenerContainer() throws Exception
createListenerContainer
in class ReplyManagerSupport
Exception
protected void doStop() throws Exception
doStop
in class ReplyManagerSupport
Exception
Apache Camel