RabbitMQ

Since Camel 2.12

Both producer and consumer are supported

The RabbitMQ component allows you to produce and consume messages from RabbitMQ instances. Using the RabbitMQ AMQP client, this component offers a pure RabbitMQ approach over the generic AMQP component.

It is recommended to use the Camel Spring RabbitMQ component, instead of using this component.

Maven users will need to add the following dependency to their pom.xml for this component:

<dependency>
    <groupId>org.apache.camel</groupId>
    <artifactId>camel-rabbitmq</artifactId>
    <version>x.x.x</version>
    <!-- use the same version as your Camel core version -->
</dependency>

URI format

rabbitmq:exchangeName?[options]

The exchange name determines the exchange to which the produced messages will be sent to. In the case of consumers, the exchange name determines the exchange the queue will be bound to.

Configuring Options

Camel components are configured on two separate levels:

  • component level

  • endpoint level

Configuring Component Options

The component level is the highest level which holds general and common configurations that are inherited by the endpoints. For example a component may have security settings, credentials for authentication, urls for network connection and so forth.

Some components only have a few options, and others may have many. Because components typically have pre configured defaults that are commonly used, then you may often only need to configure a few options on a component; or none at all.

Configuring components can be done with the Component DSL, in a configuration file (application.properties|yaml), or directly with Java code.

Configuring Endpoint Options

Where you find yourself configuring the most is on endpoints, as endpoints often have many options, which allows you to configure what you need the endpoint to do. The options are also categorized into whether the endpoint is used as consumer (from) or as a producer (to), or used for both.

Configuring endpoints is most often done directly in the endpoint URI as path and query parameters. You can also use the Endpoint DSL and DataFormat DSL as a type safe way of configuring endpoints and data formats in Java.

A good practice when configuring options is to use Property Placeholders, which allows to not hardcode urls, port numbers, sensitive information, and other settings. In other words placeholders allows to externalize the configuration from your code, and gives more flexibility and reuse.

The following two sections lists all the options, firstly for the component followed by the endpoint.

Component Options

The RabbitMQ component supports 56 options, which are listed below.

Name Description Default Type

addresses (common)

If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses. The addresses value is a string which looks like server1:12345, server2:12345.

String

autoDelete (common)

If it is true, the exchange will be deleted when it is no longer in use.

true

boolean

connectionFactory (common)

To use a custom RabbitMQ connection factory. When this option is set, all connection options (connectionTimeout, requestedChannelMax…​) set on URI are not used.

ConnectionFactory

deadLetterExchange (common)

The name of the dead letter exchange.

String

deadLetterExchangeType (common)

The type of the dead letter exchange.

Enum values:

  • direct

  • fanout

  • headers

  • topic

direct

String

deadLetterQueue (common)

The name of the dead letter queue.

String

deadLetterRoutingKey (common)

The routing key for the dead letter exchange.

String

declare (common)

If the option is true, camel declare the exchange and queue name and bind them together. If the option is false, camel won’t declare the exchange and queue name on the server.

true

boolean

durable (common)

If we are declaring a durable exchange (the exchange will survive a server restart).

true

boolean

exclusive (common)

Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.

false

boolean

hostname (common)

The hostname of the running RabbitMQ instance or cluster.

String

passive (common)

Passive queues depend on the queue already to be available at RabbitMQ.

false

boolean

portNumber (common)

Port number for the host with the running rabbitmq instance or cluster.

5672

int

skipExchangeDeclare (common)

This can be used if we need to declare the queue but not the exchange.

false

boolean

skipQueueBind (common)

If true the queue will not be bound to the exchange after declaring it.

false

boolean

skipQueueDeclare (common)

If true the producer will not declare and bind a queue. This can be used for directing messages via an existing routing key.

false

boolean

vhost (common)

The vhost for the channel.

/

String

autoAck (consumer)

If messages should be auto acknowledged.

true

boolean

bridgeErrorHandler (consumer)

Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.

false

boolean

exclusiveConsumer (consumer)

Request exclusive access to the queue (meaning only this consumer can access the queue). This is useful when you want a long-lived shared queue to be temporarily accessible by just one consumer.

false

boolean

prefetchCount (consumer)

The maximum number of messages that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

int

prefetchEnabled (consumer)

Enables the quality of service on the RabbitMQConsumer side. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

boolean

prefetchGlobal (consumer)

If the settings should be applied to the entire channel rather than each consumer You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

boolean

prefetchSize (consumer)

The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

int

recoverFromDeclareException (consumer)

Decides whether an exception during declaration of exchanges or queues is recoverable or not. If the option is false, camel will throw an exception when starting the consumer, which will interrupt application startup (e.g. in the case when the exchange / queue is already declared in RabbitMQ and has incompatible configuration). If set to true, the consumer will try to reconnect periodically.

false

boolean

threadPoolSize (consumer (advanced))

The consumer uses a Thread Pool Executor with a fixed number of threads. This setting allows you to set that number of threads.

10

int

additionalHeaders (producer)

Map of additional headers. These headers will be set only when the 'allowCustomHeaders' is set to true.

Map

additionalProperties (producer)

Map of additional properties. These are standard RabbitMQ properties as defined in com.rabbitmq.client.AMQP.BasicProperties The map keys should be from org.apache.camel.component.rabbitmq.RabbitMQConstants. Any other keys will be ignored. When the message already contains these headers they will be given precedence over these properties.

Map

allowNullHeaders (producer)

Allow pass null values to header.

false

boolean

channelPoolMaxSize (producer)

Get maximum number of opened channel in pool.

10

int

channelPoolMaxWait (producer)

Set the maximum number of milliseconds to wait for a channel from the pool.

1000

long

guaranteedDeliveries (producer)

When true, an exception will be thrown when the message cannot be delivered (basic.return) and the message is marked as mandatory. PublisherAcknowledgement will also be activated in this case. See also publisher acknowledgements - When will messages be confirmed.

false

boolean

immediate (producer)

This flag tells the server how to react if the message cannot be routed to a queue consumer immediately. If this flag is set, the server will return an undeliverable message with a Return method. If this flag is zero, the server will queue the message, but with no guarantee that it will ever be consumed. If the header is present rabbitmq.IMMEDIATE it will override this option.

false

boolean

lazyStartProducer (producer)

Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel’s routing error handlers. Beware that when the first message is processed then creating and starting the producer may take a little time and prolong the total processing time of the processing.

false

boolean

mandatory (producer)

This flag tells the server how to react if the message cannot be routed to a queue. If this flag is set, the server will return an unroutable message with a Return method. If this flag is zero, the server silently drops the message. If the header is present rabbitmq.MANDATORY it will override this option.

false

boolean

publisherAcknowledgements (producer)

When true, the message will be published with publisher acknowledgements turned on.

false

boolean

publisherAcknowledgementsTimeout (producer)

The amount of time in milliseconds to wait for a basic.ack response from RabbitMQ server.

long

args (advanced)

Specify arguments for configuring the different RabbitMQ concepts, a different prefix is required for each: Exchange: arg.exchange. Queue: arg.queue. Binding: arg.binding. DLQ: arg.dlq.queue. DLQ Binding: arg.dlq.binding. For example to declare a queue with message ttl argument: http://localhost:5672/exchange/queueargs=arg.queue.x-message-ttl=60000.

Map

autoDetectConnectionFactory (advanced)

Whether to auto-detect looking up RabbitMQ connection factory from the registry. When enabled and a single instance of the connection factory is found then it will be used. An explicit connection factory can be configured on the component or endpoint level which takes precedence.

true

boolean

automaticRecoveryEnabled (advanced)

Enables connection automatic recovery (uses connection implementation that performs automatic recovery when connection shutdown is not initiated by the application).

Boolean

autowiredEnabled (advanced)

Whether autowiring is enabled. This is used for automatic autowiring options (the option must be marked as autowired) by looking up in the registry to find if there is a single instance of matching type, which then gets configured on the component. This can be used for automatic configuring JDBC data sources, JMS connection factories, AWS Clients, etc.

true

boolean

clientProperties (advanced)

Connection client properties (client info used in negotiating with the server).

Map

connectionFactoryExceptionHandler (advanced)

Custom rabbitmq ExceptionHandler for ConnectionFactory.

ExceptionHandler

connectionTimeout (advanced)

Connection timeout.

60000

int

networkRecoveryInterval (advanced)

Network recovery interval in milliseconds (interval used when recovering from network failure).

5000

Integer

requestedChannelMax (advanced)

Connection requested channel max (max number of channels offered).

2047

int

requestedFrameMax (advanced)

Connection requested frame max (max size of frame offered).

0

int

requestedHeartbeat (advanced)

Connection requested heartbeat (heart-beat in seconds offered).

60

int

requestTimeout (advanced)

Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds).

20000

long

requestTimeoutCheckerInterval (advanced)

Set requestTimeoutCheckerInterval for inOut exchange.

1000

long

topologyRecoveryEnabled (advanced)

Enables connection topology recovery (should topology recovery be performed).

Boolean

transferException (advanced)

When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response.

false

boolean

password (security)

Password for authenticated access.

guest

String

sslProtocol (security)

Enables SSL on connection, accepted value are true, TLS and 'SSLv3.

String

trustManager (security)

Configure SSL trust manager, SSL should be enabled for this option to be effective.

TrustManager

username (security)

Username in case of authenticated access.

guest

String

Endpoint Options

The RabbitMQ endpoint is configured using URI syntax:

rabbitmq:exchangeName

with the following path and query parameters:

Path Parameters (1 parameters)

Name Description Default Type

exchangeName (common)

Required The exchange name determines the exchange to which the produced messages will be sent to. In the case of consumers, the exchange name determines the exchange the queue will be bound to.

String

Query Parameters (66 parameters)

Name Description Default Type

addresses (common)

If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses. The addresses value is a string which looks like server1:12345, server2:12345.

String

autoDelete (common)

If it is true, the exchange will be deleted when it is no longer in use.

true

boolean

automaticRecoveryEnabled (common)

Enables connection automatic recovery (uses connection implementation that performs automatic recovery when existing connection has failures).

true

Boolean

connectionFactory (common)

To use a custom RabbitMQ connection factory. When this option is set, all connection options (connectionTimeout, requestedChannelMax…​) set on URI are not used.

ConnectionFactory

deadLetterExchange (common)

The name of the dead letter exchange.

String

deadLetterExchangeType (common)

The type of the dead letter exchange.

Enum values:

  • direct

  • fanout

  • headers

  • topic

direct

String

deadLetterQueue (common)

The name of the dead letter queue.

String

deadLetterRoutingKey (common)

The routing key for the dead letter exchange.

String

declare (common)

If the option is true, camel declare the exchange and queue name and bind them together. If the option is false, camel won’t declare the exchange and queue name on the server.

true

boolean

durable (common)

If we are declaring a durable exchange (the exchange will survive a server restart).

true

boolean

exchangeType (common)

The exchange type such as direct or topic.

Enum values:

  • direct

  • fanout

  • headers

  • topic

direct

String

exclusive (common)

Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.

false

boolean

hostname (common)

The hostname of the running rabbitmq instance or cluster.

String

passive (common)

Passive queues depend on the queue already to be available at RabbitMQ.

false

boolean

portNumber (common)

Port number for the host with the running rabbitmq instance or cluster. Default value is 5672.

int

queue (common)

The queue to receive messages from.

String

routingKey (common)

The routing key to use when binding a consumer queue to the exchange. For producer routing keys, you set the header rabbitmq.ROUTING_KEY.

String

skipDlqDeclare (common)

If true the producer will not declare and bind a dead letter queue. This can be used if you have also DLQ rabbitmq consumer and you want to avoid argument clashing between Producer and Consumer. This option have no effect, if DLQ configured (deadLetterExchange option is not set).

false

boolean

skipExchangeDeclare (common)

This can be used if we need to declare the queue but not the exchange.

false

boolean

skipQueueBind (common)

If true the queue will not be bound to the exchange after declaring it.

false

boolean

skipQueueDeclare (common)

If true the producer will not declare and bind a queue. This can be used for directing messages via an existing routing key.

false

boolean

vhost (common)

The vhost for the channel.

/

String

autoAck (consumer)

If messages should be auto acknowledged.

true

boolean

concurrentConsumers (consumer)

Number of concurrent consumers when consuming from broker. (eg similar as to the same option for the JMS component).

1

int

consumerTag (consumer)

Specify a client-generated consumer tag to establish context when invoking the consume operation.

String

exclusiveConsumer (consumer)

Request exclusive access to the queue (meaning only this consumer can access the queue). This is useful when you want a long-lived shared queue to be temporarily accessible by just one consumer.

false

boolean

prefetchCount (consumer)

The maximum number of messages that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

int

prefetchEnabled (consumer)

Enables the quality of service on the RabbitMQConsumer side. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

boolean

prefetchGlobal (consumer)

If the settings should be applied to the entire channel rather than each consumer You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

boolean

prefetchSize (consumer)

The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

int

recoverFromDeclareException (consumer)

Decides whether an exception during declaration of exchanges or queues is recoverable or not. If the option is false, camel will throw an exception when starting the consumer, which will interrupt application startup (e.g. in the case when the exchange / queue is already declared in RabbitMQ and has incompatible configuration). If set to true, the consumer will try to reconnect periodically.

true

boolean

reQueue (consumer)

This is used by the consumer to control rejection of the message. When the consumer is complete processing the exchange, and if the exchange failed, then the consumer is going to reject the message from the RabbitMQ broker. If the header CamelRabbitmqRequeue is present then the value of the header will be used, otherwise this endpoint value is used as fallback. If the value is false (by default) then the message is discarded/dead-lettered. If the value is true, then the message is re-queued.

false

boolean

bridgeErrorHandler (consumer (advanced))

Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.

false

boolean

exceptionHandler (consumer (advanced))

To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored.

ExceptionHandler

exchangePattern (consumer (advanced))

Sets the exchange pattern when the consumer creates an exchange.

Enum values:

  • InOnly

  • InOut

  • InOptionalOut

ExchangePattern

threadPoolSize (consumer (advanced))

The consumer uses a Thread Pool Executor with a fixed number of threads. This setting allows you to set that number of threads.

10

int

additionalHeaders (producer)

Map of additional headers. These headers will be set only when the 'allowCustomHeaders' is set to true.

Map

additionalProperties (producer)

Map of additional properties. These are standard RabbitMQ properties as defined in com.rabbitmq.client.AMQP.BasicProperties. The map keys should be from org.apache.camel.component.rabbitmq.RabbitMQConstants. Any other keys will be ignored.

Map

allowCustomHeaders (producer)

Allow pass custom values to header.

false

boolean

allowNullHeaders (producer)

Allow pass null values to header.

false

boolean

bridgeEndpoint (producer)

If the bridgeEndpoint is true, the producer will ignore the message header of rabbitmq.EXCHANGE_NAME and rabbitmq.ROUTING_KEY.

false

boolean

channelPoolMaxSize (producer)

Get maximum number of opened channel in pool.

10

int

channelPoolMaxWait (producer)

Set the maximum number of milliseconds to wait for a channel from the pool.

1000

long

guaranteedDeliveries (producer)

When true, an exception will be thrown when the message cannot be delivered (basic.return) and the message is marked as mandatory. PublisherAcknowledgement will also be activated in this case. See also publisher acknowledgements - When will messages be confirmed.

false

boolean

immediate (producer)

This flag tells the server how to react if the message cannot be routed to a queue consumer immediately. If this flag is set, the server will return an undeliverable message with a Return method. If this flag is zero, the server will queue the message, but with no guarantee that it will ever be consumed. If the header is present rabbitmq.IMMEDIATE it will override this option.

false

boolean

mandatory (producer)

This flag tells the server how to react if the message cannot be routed to a queue. If this flag is set, the server will return an unroutable message with a Return method. If this flag is zero, the server silently drops the message. If the header is present rabbitmq.MANDATORY it will override this option.

false

boolean

publisherAcknowledgements (producer)

When true, the message will be published with publisher acknowledgements turned on.

false

boolean

publisherAcknowledgementsTimeout (producer)

The amount of time in milliseconds to wait for a basic.ack response from RabbitMQ server.

long

lazyStartProducer (producer (advanced))

Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel’s routing error handlers. Beware that when the first message is processed then creating and starting the producer may take a little time and prolong the total processing time of the processing.

false

boolean

allowMessageBodySerialization (advanced)

Whether to allow Java serialization of the message body or not. If this value is true, the message body will be serialized on the producer side using Java serialization, if no type converter can handle the message body. On the consumer side, it will deserialize the message body if this value is true and the message contains a CamelSerialize header. Setting this value to true may introduce a security vulnerability as it allows an attacker to attempt to deserialize to a gadget object which could result in a RCE or other security vulnerability.

false

boolean

args (advanced)

Specify arguments for configuring the different RabbitMQ concepts, a different prefix is required for each: Exchange: arg.exchange. Queue: arg.queue. Binding: arg.binding. DLQ: arg.dlq.queue. DLQ binding: arg.dlq.binding. For example to declare a queue with message ttl argument: http://localhost:5672/exchange/queueargs=arg.queue.x-message-ttl=60000.

Map

clientProperties (advanced)

Connection client properties (client info used in negotiating with the server).

Map

connectionFactoryExceptionHandler (advanced)

Custom rabbitmq ExceptionHandler for ConnectionFactory.

ExceptionHandler

connectionTimeout (advanced)

Connection timeout.

60000

int

networkRecoveryInterval (advanced)

Network recovery interval in milliseconds (interval used when recovering from network failure).

5000

Integer

requestedChannelMax (advanced)

Connection requested channel max (max number of channels offered).

2047

int

requestedFrameMax (advanced)

Connection requested frame max (max size of frame offered).

0

int

requestedHeartbeat (advanced)

Connection requested heartbeat (heart-beat in seconds offered).

60

int

requestTimeout (advanced)

Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds).

20000

long

requestTimeoutCheckerInterval (advanced)

Set requestTimeoutCheckerInterval for inOut exchange.

1000

long

topologyRecoveryEnabled (advanced)

Enables connection topology recovery (should topology recovery be performed).

Boolean

transferException (advanced)

When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response.

false

boolean

password (security)

Password for authenticated access.

guest

String

sslProtocol (security)

Enables SSL on connection, accepted value are true, TLS and 'SSLv3.

String

trustManager (security)

Configure SSL trust manager, SSL should be enabled for this option to be effective.

TrustManager

username (security)

Username in case of authenticated access.

guest

String

Using a connection factory

To connect to RabbitMQ you can setup a ConnectionFactory (same as with JMS) with the login details such as:

<bean id="rabbitConnectionFactory" class="com.rabbitmq.client.ConnectionFactory">
  <property name="host" value="localhost"/>
  <property name="port" value="5672"/>
  <property name="username" value="camel"/>
  <property name="password" value="bugsbunny"/>
</bean>

And then refer to the connection factory in the endpoint uri as shown below:

<camelContext>
  <route>
    <from uri="direct:rabbitMQEx2"/>
    <to uri="rabbitmq:ex2?connectionFactory=#rabbitConnectionFactory"/>
  </route>
</camelContext>

The ConnectionFactory is auto-detected by default, so you can just do

<camelContext>
  <route>
    <from uri="direct:rabbitMQEx2"/>
    <to uri="rabbitmq:ex2"/>
  </route>
</camelContext>

In case you have multiple connection factories in your application or multiple connection factories in your registry, don’t forget to set the autoDetectConnectionFactory to false.

Message Headers

The RabbitMQ component supports 23 message header(s), which is/are listed below:

Name Description Default Type

CamelRabbitmqRoutingKey (common)

Constant: ROUTING_KEY

Consumer: The routing key that was used to receive the message, or the routing key that will be used when producing a message Producer: The routing key that will be used when sending the message.

String

CamelRabbitmqExchangeOverrideName (common)

Constant: EXCHANGE_OVERRIDE_NAME

Used for force sending the message to this exchange instead of the endpoint configured name on the producer.

String

CamelRabbitmqExchangeName (common)

Constant: EXCHANGE_NAME

Consumer: The exchange the message was received from Producer: The exchange the message was received from.

String

CamelRabbitmqContentType (common)

Constant: CONTENT_TYPE

The contentType to set on the RabbitMQ message.

String

CamelRabbitmqPriority (common)

Constant: PRIORITY

The priority header to set on the RabbitMQ message.

int

CamelRabbitmqDeliveryTag (common)

Constant: DELIVERY_TAG

The rabbitmq delivery tag of the received message.

long

CamelRabbitmqRedeliveryTag (common)

Constant: REDELIVERY_TAG

Whether the message is a redelivered.

boolean

CamelRabbitmqCorrelationId (common)

Constant: CORRELATIONID

The correlationId to set on the RabbitMQ message.

String

CamelRabbitmqMessageId (common)

Constant: MESSAGE_ID

The message id to set on the RabbitMQ message.

String

CamelRabbitmqDeliveryMode (common)

Constant: DELIVERY_MODE

If the message should be persistent or not.

Integer

CamelRabbitmqUserId (common)

Constant: USERID

The userId to set on the RabbitMQ message.

String

CamelRabbitmqClusterId (common)

Constant: CLUSTERID

The clusterId to set on the RabbitMQ message.

String

CamelRabbitmqRequestTimeout (common)

Constant: REQUEST_TIMEOUT

The timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds).

long

CamelRabbitmqReplyTo (common)

Constant: REPLY_TO

The replyTo to set on the RabbitMQ message.

String

CamelRabbitmqContentEncoding (common)

Constant: CONTENT_ENCODING

The contentEncoding to set on the RabbitMQ message.

String

CamelRabbitmqType (common)

Constant: TYPE

The type to set on the RabbitMQ message.

String

CamelRabbitmqExpiration (common)

Constant: EXPIRATION

The expiration to set on the RabbitMQ message.

String

CamelRabbitmqTimestamp (common)

Constant: TIMESTAMP

The timestamp to set on the RabbitMQ message.

Date

CamelRabbitmqAppId (common)

Constant: APP_ID

The appId to set on the RabbitMQ message.

String

CamelRabbitmqRequeue (common)

Constant: REQUEUE

This is used by the consumer to control rejection of the message. When the consumer is complete processing the exchange, and if the exchange failed, then the consumer is going to reject the message from the RabbitMQ broker. The value of this header controls this behavior. If the value is false (by default) then the message is discarded/dead-lettered. If the value is true, then the message is re-queued.

boolean

CamelRabbitmqMandatory (common)

Constant: MANDATORY

The flag telling the server how to react if the message cannot be routed to a queue.

Boolean

CamelRabbitmqImmediate (common)

Constant: IMMEDIATE

The flag telling the server how to react if the message cannot be routed to a queue consumer immediately.

Boolean

CamelMessageTimestamp (common)

Constant: MESSAGE_TIMESTAMP

The timestamp of the RabbitMQ message.

long

Troubleshooting headers

Watch out when consuming from a RabbitMq queue and producing to the same RabbitMq exchange. The header details on the exchange may be populated with headers that will not be overriden by the destination endpoint. The following example will help understand the pitfall.

from("rabbitmq:A?queue=IN&declare=false&autoDelete=false&arg.queue.x-message-ttl=20000")
  // ... your route
  .to("rabbitmq:A?queue=OUT&routingKey=OUT&declare=false&autoDelete=false&arg.queue.x-message-ttl=20000");

You would think that it would be a straight forward operation. However, if the source queue has a routing key set in the headers, it will pass down to the destination and not be overriden with the URI query parameters. Because the exchange is the same and the routing key is the same, an infinitely growing loop is created.

Either make a second exchange for the producer to avoid the headers to pass through or manually access the exchange headers in a processor and get rid of the misbehaving key.

from("rabbitmq:A?queue=IN&declare=false&autoDelete=false&arg.queue.x-message-ttl=20000")
  // ...
  .process(e -> {
    InputModel input = e.getMessage().getBody(InputModel.class);
    e.getMessage().removeHeader("CamelRabbitmqRoutingKey");
    OutputModel output = ...
    e.getMessage().setBody(output);
  })
  // ...
  .to("rabbitmq:A?queue=OUT&routingKey=OUT&declare=false&autoDelete=false&arg.queue.x-message-ttl=20000");

Now you are at least guaranteed to not create a loop from the camel route.

Allowing custom Headers

The allowCustomHeaders endpoint option can be used to avoid adding custom headers to the message sent to RabbitMQ. If set to false, the user will have only CamelRabbitmq* headers in the payload of the message. Default value for this option is true.

If you decide to use the allowCustomHeaders option, don’t add sensitive information as header. It’s not recommended and it’s dangerous. Don’t do it.

Message Body

The component will use the camel exchange in body as the rabbit mq message body. The camel exchange in object must be convertible to a byte array. Otherwise the producer will throw an exception of unsupported body type.

Samples

To receive messages from a queue that is bound to an exchange A with the routing key B,

from("rabbitmq:A?routingKey=B")
  .to("log:cheese");

To receive messages from a queue with a single thread with auto acknowledge disabled.

from("rabbitmq:A?routingKey=B&threadPoolSize=1&autoAck=false")
  .to("log:cheese");

To send messages to an exchange called C

from("direct:foo")
  .to("rabbitmq:C");

Declaring a headers exchange and queue

from("rabbitmq:ex?exchangeType=headers&queue=q&bindingArgs=#bindArgs")
  .to("log:cheese");

and place corresponding Map<String, Object> with the id of "bindArgs" in the Registry.

For example declaring a method in Spring

@Bean(name = "bindArgs")
public Map<String, Object> bindArgsBuilder() {
    return new HashMap<String, Object>() {{
        put("binding.foo", "bar");
    }};
}

Spring Boot Auto-Configuration

When using rabbitmq with Spring Boot make sure to use the following Maven dependency to have support for auto configuration:

<dependency>
  <groupId>org.apache.camel.springboot</groupId>
  <artifactId>camel-rabbitmq-starter</artifactId>
  <version>x.x.x</version>
  <!-- use the same version as your Camel core version -->
</dependency>

The component supports 57 options, which are listed below.

Name Description Default Type

camel.component.rabbitmq.additional-headers

Map of additional headers. These headers will be set only when the 'allowCustomHeaders' is set to true.

Map

camel.component.rabbitmq.additional-properties

Map of additional properties. These are standard RabbitMQ properties as defined in com.rabbitmq.client.AMQP.BasicProperties The map keys should be from org.apache.camel.component.rabbitmq.RabbitMQConstants. Any other keys will be ignored. When the message already contains these headers they will be given precedence over these properties.

Map

camel.component.rabbitmq.addresses

If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses. The addresses value is a string which looks like server1:12345, server2:12345.

String

camel.component.rabbitmq.allow-null-headers

Allow pass null values to header.

false

Boolean

camel.component.rabbitmq.args

Specify arguments for configuring the different RabbitMQ concepts, a different prefix is required for each: Exchange: arg.exchange. Queue: arg.queue. Binding: arg.binding. DLQ: arg.dlq.queue. DLQ Binding: arg.dlq.binding. For example to declare a queue with message ttl argument: http://localhost:5672/exchange/queueargs=arg.queue.x-message-ttl=60000.

Map

camel.component.rabbitmq.auto-ack

If messages should be auto acknowledged.

true

Boolean

camel.component.rabbitmq.auto-delete

If it is true, the exchange will be deleted when it is no longer in use.

true

Boolean

camel.component.rabbitmq.auto-detect-connection-factory

Whether to auto-detect looking up RabbitMQ connection factory from the registry. When enabled and a single instance of the connection factory is found then it will be used. An explicit connection factory can be configured on the component or endpoint level which takes precedence.

true

Boolean

camel.component.rabbitmq.automatic-recovery-enabled

Enables connection automatic recovery (uses connection implementation that performs automatic recovery when connection shutdown is not initiated by the application).

Boolean

camel.component.rabbitmq.autowired-enabled

Whether autowiring is enabled. This is used for automatic autowiring options (the option must be marked as autowired) by looking up in the registry to find if there is a single instance of matching type, which then gets configured on the component. This can be used for automatic configuring JDBC data sources, JMS connection factories, AWS Clients, etc.

true

Boolean

camel.component.rabbitmq.bridge-error-handler

Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.

false

Boolean

camel.component.rabbitmq.channel-pool-max-size

Get maximum number of opened channel in pool.

10

Integer

camel.component.rabbitmq.channel-pool-max-wait

Set the maximum number of milliseconds to wait for a channel from the pool.

1000

Long

camel.component.rabbitmq.client-properties

Connection client properties (client info used in negotiating with the server).

Map

camel.component.rabbitmq.connection-factory

To use a custom RabbitMQ connection factory. When this option is set, all connection options (connectionTimeout, requestedChannelMax…​) set on URI are not used. The option is a com.rabbitmq.client.ConnectionFactory type.

ConnectionFactory

camel.component.rabbitmq.connection-factory-exception-handler

Custom rabbitmq ExceptionHandler for ConnectionFactory. The option is a com.rabbitmq.client.ExceptionHandler type.

ExceptionHandler

camel.component.rabbitmq.connection-timeout

Connection timeout.

60000

Integer

camel.component.rabbitmq.dead-letter-exchange

The name of the dead letter exchange.

String

camel.component.rabbitmq.dead-letter-exchange-type

The type of the dead letter exchange.

direct

String

camel.component.rabbitmq.dead-letter-queue

The name of the dead letter queue.

String

camel.component.rabbitmq.dead-letter-routing-key

The routing key for the dead letter exchange.

String

camel.component.rabbitmq.declare

If the option is true, camel declare the exchange and queue name and bind them together. If the option is false, camel won’t declare the exchange and queue name on the server.

true

Boolean

camel.component.rabbitmq.durable

If we are declaring a durable exchange (the exchange will survive a server restart).

true

Boolean

camel.component.rabbitmq.enabled

Whether to enable auto configuration of the rabbitmq component. This is enabled by default.

Boolean

camel.component.rabbitmq.exclusive

Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.

false

Boolean

camel.component.rabbitmq.exclusive-consumer

Request exclusive access to the queue (meaning only this consumer can access the queue). This is useful when you want a long-lived shared queue to be temporarily accessible by just one consumer.

false

Boolean

camel.component.rabbitmq.guaranteed-deliveries

When true, an exception will be thrown when the message cannot be delivered (basic.return) and the message is marked as mandatory. PublisherAcknowledgement will also be activated in this case. See also publisher acknowledgements - When will messages be confirmed.

false

Boolean

camel.component.rabbitmq.hostname

The hostname of the running RabbitMQ instance or cluster.

String

camel.component.rabbitmq.immediate

This flag tells the server how to react if the message cannot be routed to a queue consumer immediately. If this flag is set, the server will return an undeliverable message with a Return method. If this flag is zero, the server will queue the message, but with no guarantee that it will ever be consumed. If the header is present rabbitmq.IMMEDIATE it will override this option.

false

Boolean

camel.component.rabbitmq.lazy-start-producer

Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel’s routing error handlers. Beware that when the first message is processed then creating and starting the producer may take a little time and prolong the total processing time of the processing.

false

Boolean

camel.component.rabbitmq.mandatory

This flag tells the server how to react if the message cannot be routed to a queue. If this flag is set, the server will return an unroutable message with a Return method. If this flag is zero, the server silently drops the message. If the header is present rabbitmq.MANDATORY it will override this option.

false

Boolean

camel.component.rabbitmq.network-recovery-interval

Network recovery interval in milliseconds (interval used when recovering from network failure).

5000

Integer

camel.component.rabbitmq.passive

Passive queues depend on the queue already to be available at RabbitMQ.

false

Boolean

camel.component.rabbitmq.password

Password for authenticated access.

guest

String

camel.component.rabbitmq.port-number

Port number for the host with the running rabbitmq instance or cluster.

5672

Integer

camel.component.rabbitmq.prefetch-count

The maximum number of messages that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

Integer

camel.component.rabbitmq.prefetch-enabled

Enables the quality of service on the RabbitMQConsumer side. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

Boolean

camel.component.rabbitmq.prefetch-global

If the settings should be applied to the entire channel rather than each consumer You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

false

Boolean

camel.component.rabbitmq.prefetch-size

The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited. You need to specify the option of prefetchSize, prefetchCount, prefetchGlobal at the same time.

Integer

camel.component.rabbitmq.publisher-acknowledgements

When true, the message will be published with publisher acknowledgements turned on.

false

Boolean

camel.component.rabbitmq.publisher-acknowledgements-timeout

The amount of time in milliseconds to wait for a basic.ack response from RabbitMQ server.

Long

camel.component.rabbitmq.recover-from-declare-exception

Decides whether an exception during declaration of exchanges or queues is recoverable or not. If the option is false, camel will throw an exception when starting the consumer, which will interrupt application startup (e.g. in the case when the exchange / queue is already declared in RabbitMQ and has incompatible configuration). If set to true, the consumer will try to reconnect periodically.

false

Boolean

camel.component.rabbitmq.request-timeout

Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds).

20000

Long

camel.component.rabbitmq.request-timeout-checker-interval

Set requestTimeoutCheckerInterval for inOut exchange.

1000

Long

camel.component.rabbitmq.requested-channel-max

Connection requested channel max (max number of channels offered).

2047

Integer

camel.component.rabbitmq.requested-frame-max

Connection requested frame max (max size of frame offered).

0

Integer

camel.component.rabbitmq.requested-heartbeat

Connection requested heartbeat (heart-beat in seconds offered).

60

Integer

camel.component.rabbitmq.skip-exchange-declare

This can be used if we need to declare the queue but not the exchange.

false

Boolean

camel.component.rabbitmq.skip-queue-bind

If true the queue will not be bound to the exchange after declaring it.

false

Boolean

camel.component.rabbitmq.skip-queue-declare

If true the producer will not declare and bind a queue. This can be used for directing messages via an existing routing key.

false

Boolean

camel.component.rabbitmq.ssl-protocol

Enables SSL on connection, accepted value are true, TLS and 'SSLv3.

String

camel.component.rabbitmq.thread-pool-size

The consumer uses a Thread Pool Executor with a fixed number of threads. This setting allows you to set that number of threads.

10

Integer

camel.component.rabbitmq.topology-recovery-enabled

Enables connection topology recovery (should topology recovery be performed).

Boolean

camel.component.rabbitmq.transfer-exception

When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response.

false

Boolean

camel.component.rabbitmq.trust-manager

Configure SSL trust manager, SSL should be enabled for this option to be effective. The option is a javax.net.ssl.TrustManager type.

TrustManager

camel.component.rabbitmq.username

Username in case of authenticated access.

guest

String

camel.component.rabbitmq.vhost

The vhost for the channel.

/

String