Interface ReplyManager

All Known Implementing Classes:
ReplyManagerSupport, TemporaryQueueReplyManager

public interface ReplyManager
The ReplyManager is responsible for handling request-reply over RabbitMQ.
  • Method Details

    • setEndpoint

      void setEndpoint(RabbitMQEndpoint endpoint)
      Sets the belonging RabbitMQEndpoint
    • setReplyTo

      void setReplyTo(String replyTo)
      Sets the reply to queue the manager should listen for replies.

      The queue is either a temporary or a persistent queue.

    • getReplyTo

      String getReplyTo()
      Gets the reply to queue being used
    • registerReply

      String registerReply(ReplyManager replyManager, org.apache.camel.Exchange exchange, org.apache.camel.AsyncCallback callback, String originalCorrelationId, String correlationId, long requestTimeout)
      Register a reply
      Parameters:
      replyManager - the reply manager being used
      exchange - the exchange
      callback - the callback
      originalCorrelationId - an optional original correlation id
      correlationId - the correlation id to expect being used
      requestTimeout - the timeout
      Returns:
      the correlation id used
    • setScheduledExecutorService

      void setScheduledExecutorService(ScheduledExecutorService executorService)
      Sets the scheduled to use when checking for timeouts (no reply received within a given time period)
    • updateCorrelationId

      void updateCorrelationId(String correlationId, String newCorrelationId, long requestTimeout)
      Updates the correlation id to the new correlation id.

      This is only used when useMessageIDasCorrelationID option is used, which means a provisional correlation id is first used, then after the message has been sent, the real correlation id is known. This allows us then to update the internal mapping to expect the real correlation id.

      Parameters:
      correlationId - the provisional correlation id
      newCorrelationId - the real correlation id
      requestTimeout - the timeout
    • processReply

      void processReply(ReplyHolder holder)
      Process the reply
      Parameters:
      holder - containing needed data to process the reply and continue routing
    • cancelCorrelationId

      void cancelCorrelationId(String correlationId)
      Unregister a correlationId when you no longer need a reply