Class RabbitMQConstants

java.lang.Object
org.apache.camel.component.rabbitmq.RabbitMQConstants

public final class RabbitMQConstants extends Object
  • Field Details

    • ROUTING_KEY

      @Metadata(description="*Consumer:* The routing key that was used to receive the message, or the routing key\nthat will be used when producing a message\n *Producer:* The routing key that will be used when sending the message", javaType="String") public static final String ROUTING_KEY
      See Also:
    • EXCHANGE_OVERRIDE_NAME

      @Metadata(description="Used for force sending the message to this exchange instead of the endpoint configured name on the producer", javaType="String") public static final String EXCHANGE_OVERRIDE_NAME
      See Also:
    • EXCHANGE_NAME

      @Metadata(description="*Consumer:* The exchange the message was received from\n *Producer:* The exchange the message was received from", javaType="String") public static final String EXCHANGE_NAME
      See Also:
    • CONTENT_TYPE

      @Metadata(description="The contentType to set on the RabbitMQ message", javaType="String") public static final String CONTENT_TYPE
      See Also:
    • PRIORITY

      @Metadata(description="The priority header to set on the RabbitMQ message", javaType="int") public static final String PRIORITY
      See Also:
    • DELIVERY_TAG

      @Metadata(description="The rabbitmq delivery tag of the received message", javaType="long") public static final String DELIVERY_TAG
      See Also:
    • REDELIVERY_TAG

      @Metadata(description="Whether the message is a redelivered", javaType="boolean") public static final String REDELIVERY_TAG
      See Also:
    • CORRELATIONID

      @Metadata(description="The correlationId to set on the RabbitMQ message.", javaType="String") public static final String CORRELATIONID
      See Also:
    • MESSAGE_ID

      @Metadata(description="The message id to set on the RabbitMQ message.", javaType="String") public static final String MESSAGE_ID
      See Also:
    • DELIVERY_MODE

      @Metadata(description="If the message should be persistent or not", javaType="Integer") public static final String DELIVERY_MODE
      See Also:
    • USERID

      @Metadata(description="The userId to set on the RabbitMQ message", javaType="String") public static final String USERID
      See Also:
    • CLUSTERID

      @Metadata(description="The clusterId to set on the RabbitMQ message", javaType="String") public static final String CLUSTERID
      See Also:
    • REQUEST_TIMEOUT

      @Metadata(description="The timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds)", javaType="long") public static final String REQUEST_TIMEOUT
      See Also:
    • REPLY_TO

      @Metadata(description="The replyTo to set on the RabbitMQ message", javaType="String") public static final String REPLY_TO
      See Also:
    • CONTENT_ENCODING

      @Metadata(description="The contentEncoding to set on the RabbitMQ message", javaType="String") public static final String CONTENT_ENCODING
      See Also:
    • TYPE

      @Metadata(description="The type to set on the RabbitMQ message", javaType="String") public static final String TYPE
      See Also:
    • EXPIRATION

      @Metadata(description="The expiration to set on the RabbitMQ message", javaType="String") public static final String EXPIRATION
      See Also:
    • TIMESTAMP

      @Metadata(description="The timestamp to set on the RabbitMQ message", javaType="java.util.Date") public static final String TIMESTAMP
      See Also:
    • APP_ID

      @Metadata(description="The appId to set on the RabbitMQ message", javaType="String") public static final String APP_ID
      See Also:
    • REQUEUE

      @Metadata(description="This is used by the consumer to control rejection of the\nmessage. When the consumer is complete processing the exchange, and if\nthe exchange failed, then the consumer is going to reject the message\nfrom the RabbitMQ broker. The value of this header controls this\nbehavior. If the value is false (by default) then the message is\ndiscarded/dead-lettered. If the value is true, then the message is\nre-queued.", javaType="boolean") public static final String REQUEUE
      See Also:
    • MANDATORY

      @Metadata(description="The flag telling the server how to react if the message cannot be routed to a queue.", javaType="Boolean") public static final String MANDATORY
      See Also:
    • IMMEDIATE

      @Metadata(description="The flag telling the server how to react if the message cannot be routed to a queue consumer immediately.", javaType="Boolean") public static final String IMMEDIATE
      See Also:
    • MESSAGE_TIMESTAMP

      @Metadata(description="The timestamp of the RabbitMQ message", javaType="long") public static final String MESSAGE_TIMESTAMP
      See Also:
    • RABBITMQ_DEAD_LETTER_EXCHANGE

      public static final String RABBITMQ_DEAD_LETTER_EXCHANGE
      See Also:
    • RABBITMQ_DEAD_LETTER_ROUTING_KEY

      public static final String RABBITMQ_DEAD_LETTER_ROUTING_KEY
      See Also:
    • RABBITMQ_DIRECT_REPLY_EXCHANGE

      public static final String RABBITMQ_DIRECT_REPLY_EXCHANGE
      See Also:
    • RABBITMQ_DIRECT_REPLY_ROUTING_KEY

      public static final String RABBITMQ_DIRECT_REPLY_ROUTING_KEY
      See Also:
    • RABBITMQ_QUEUE_LENGTH_LIMIT_KEY

      public static final String RABBITMQ_QUEUE_LENGTH_LIMIT_KEY
      See Also:
    • RABBITMQ_QUEUE_MAX_PRIORITY_KEY

      public static final String RABBITMQ_QUEUE_MAX_PRIORITY_KEY
      See Also:
    • RABBITMQ_QUEUE_MESSAGE_TTL_KEY

      public static final String RABBITMQ_QUEUE_MESSAGE_TTL_KEY
      See Also:
    • RABBITMQ_QUEUE_TTL_KEY

      public static final String RABBITMQ_QUEUE_TTL_KEY
      See Also:
    • RABBITMQ_QUEUE_SINGLE_ACTIVE_CONSUMER_KEY

      public static final String RABBITMQ_QUEUE_SINGLE_ACTIVE_CONSUMER_KEY
      See Also:
    • BASIC_AMQP_PROPERTIES

      public static final Set<String> BASIC_AMQP_PROPERTIES