Rechercher

Ce contenu n'est pas disponible dans la langue sélectionnée.

Chapter 125. Spring RabbitMQ

download PDF

Since Camel 3.8

Both producer and consumer are supported

The Spring RabbitMQ component allows you to produce and consume messages from RabbitMQ instances using the Spring RabbitMQ client.

125.1. Dependencies

When using spring-rabbitmq with Red Hat build of Camel Spring Boot use the following Maven dependency to enable support for auto configuration:

<dependency>
  <groupId>org.apache.camel.springboot</groupId>
  <artifactId>camel-spring-rabbitmq-starter</artifactId>
</dependency>

The version is specified using BOM in the following way.

<dependencyManagement>
        <dependencies>
            <dependency>
                <groupId>com.redhat.camel.springboot.platform</groupId>
                <artifactId>camel-spring-boot-bom</artifactId>
                <version>${camel-spring-boot-version}</version>
                <type>pom</type>
                <scope>import</scope>
            </dependency>
        </dependencies>
    </dependencyManagement>

125.2. URI format

spring-rabbitmq:exchangeName?[options]

The exchangeName determines the exchange to which the produced messages are sent to. In the case of consumers, the exchangeName determines the exchange the queue is bound to.

125.3. Configuring Options

Camel components are configured on two levels:

  • Component level
  • Endpoint level

125.3.1. Component Level Options

The component level is the highest level. The configurations you define at this level are inherited by all the endpoints. For example, a component can have security settings, credentials for authentication, urls for network connection, and so on.

Since components typically have pre-configured defaults for the most common cases, you may need to only configure a few component options, or maybe none at all.

You can configure components with Component DSL in a configuration file (application.properties|yaml), or directly with Java code.

125.3.2. Endpoint Level Options

At the Endpoint level you have many options, which you can use to configure what you want the endpoint to do. The options are categorized according to whether the endpoint is used as a consumer (from) or as a producer (to) or used for both.

You can configure endpoints directly in the endpoint URI as path and query parameters. You can also use Endpoint DSL and DataFormat DSL as type safe ways of configuring endpoints and data formats in Java.

When configuring options, use Property Placeholders for urls, port numbers, sensitive information, and other settings.

Placeholders allows you to externalize the configuration from your code, giving you more flexible and reusable code.

125.4. Component Options

The Spring RabbitMQ component supports 29 options that are listed below.

NameDescriptionDefaultType

amqpAdmin (common)

Autowired Optional AMQP Admin service to use for auto declaring elements (queues, exchanges, bindings).

 

AmqpAdmin

connectionFactory (common)

Autowired The connection factory to be use. A connection factory must be configured either on the component or endpoint.

 

ConnectionFactory

testConnectionOnStartup (common)

Specifies whether to test the connection on startup. This ensures that when Camel starts that all the JMS consumers have a valid connection to the JMS broker. If a connection cannot be granted then Camel throws an exception on startup. This ensures that Camel is not started with failed connections. The JMS producers is tested as well.

false

boolean

autoDeclare (consumer)

Specifies whether the consumer should auto declare binding between exchange, queue and routing key when starting. Enabling this can be good for development to make it easy to standup exchanges, queues and bindings on the broker.

false

boolean

autoStartup (consumer)

Specifies whether the consumer container should auto-startup.

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

deadLetterExchange (consumer)

The name of the dead letter exchange.

 

String

deadLetterExchangeType (consumer)

The type of the dead letter exchange.

Enum values:

  • direct
  • fanout
  • headers
  • topic

direct

String

deadLetterQueue (consumer)

The name of the dead letter queue.

 

String

deadLetterRoutingKey (consumer)

The routing key for the dead letter exchange.

 

String

maximumRetryAttempts (consumer)

How many times a Rabbitmq consumer will retry the same message if Camel failed to process the message.

5

int

rejectAndDontRequeue (consumer)

Whether a Rabbitmq consumer should reject the message without requeuing. This enables failed messages to be sent to a Dead Letter Exchange/Queue, if the broker is so configured.

true

boolean

retryDelay (consumer)

Delay in msec a Rabbitmq consumer will wait before redelivering a message that Camel failed to process.

1000

int

concurrentConsumers (consumer (advanced))

The number of consumers.

1

int

errorHandler (consumer (advanced))

To use a custom ErrorHandler for handling exceptions from the message listener (consumer).

 

ErrorHandler

listenerContainerFactory (consumer (advanced))

To use a custom factory for creating and configuring ListenerContainer to be used by the consumer for receiving messages.

 

ListenerContainerFactory

maxConcurrentConsumers (consumer (advanced))

The maximum number of consumers (available only with SMLC).

 

Integer

messageListenerContainerType (consumer (advanced))

The type of the MessageListenerContainer.

Enum values:

  • DMLC
  • SMLC

DMLC

String

prefetchCount (consumer (advanced))

Tell the broker how many messages to send to each consumer in a single request. Often this can be set quite high to improve throughput.

250

int

retry (consumer (advanced))

Custom retry configuration to use. If this is configured then the other settings such as maximumRetryAttempts for retry are not in use.

 

RetryOperationsInterceptor

shutdownTimeout (consumer (advanced))

The time to wait for workers in milliseconds after the container is stopped. If any workers are active when the shutdown signal comes they will be allowed to finish processing as long as they can finish within this timeout.

5000

long

allowNullBody (producer)

Whether to allow sending messages with no body. If this option is false and the message body is null, then an MessageConversionException is thrown.

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

replyTimeout (producer)

Specify the timeout in milliseconds to be used when waiting for a reply message when doing request/reply messaging. The default value is 5 seconds. A negative value indicates an indefinite timeout.

5000

long

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

ignoreDeclarationExceptions (advanced)

Switch on ignore exceptions such as mismatched properties when declaring.

false

boolean

messageConverter (advanced)

To use a custom MessageConverter so you can be in control how to map to/from a org.springframework.amqp.core.Message.

 

MessageConverter

messagePropertiesConverter (advanced)

To use a custom MessagePropertiesConverter so you can be in control how to map to/from a org.springframework.amqp.core.MessageProperties.

 

MessagePropertiesConverter

headerFilterStrategy (filter)

To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter header to and from Camel message.

 

HeaderFilterStrategy

125.5. Endpoint Options

The Spring RabbitMQ endpoint is configured using URI syntax:

spring-rabbitmq:exchangeName

Following are the path and query parameters:

125.5.1. Path Parameters (1 parameters)

NameDescriptionDefaultType

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. Note: to use default exchange then do not use empty name, but use default instead.

 

String

125.5.2. Query Parameters (34 parameters)

NameDescriptionDefaultType

connectionFactory (common)

The connection factory to be use. A connection factory must be configured either on the component or endpoint.

 

ConnectionFactory

disableReplyTo (common)

Specifies whether Camel ignores the ReplyTo header in messages. If true, Camel does not send a reply back to the destination specified in the ReplyTo header. You can use this option if you want Camel to consume from a route and you do not want Camel to automatically send back a reply message because another component in your code handles the reply message. You can also use this option if you want to use Camel as a proxy between different message brokers and you want to route message from one system to another.

false

boolean

routingKey (common)

The value of a routing key to use. Default is empty which is not helpful when using the default (or any direct) exchange, but fine if the exchange is a headers exchange for instance.

 

String

testConnectionOnStartup (common)

Specifies whether to test the connection on startup. This ensures that when Camel starts that all the JMS consumers have a valid connection to the JMS broker. If a connection cannot be granted then Camel throws an exception on startup. This ensures that Camel is not started with failed connections. The JMS producers is tested as well.

false

boolean

acknowledgeMode (consumer)

Flag controlling the behaviour of the container with respect to message acknowledgement. The most common usage is to let the container handle the acknowledgements (so the listener doesn’t need to know about the channel or the message). Set to AcknowledgeMode.MANUAL if the listener will send the acknowledgements itself using Channel.basicAck(long, boolean). Manual acks are consistent with either a transactional or non-transactional channel, but if you are doing no other work on the channel at the same other than receiving a single message then the transaction is probably unnecessary. Set to AcknowledgeMode.NONE to tell the broker not to expect any acknowledgements, and it will assume all messages are acknowledged as soon as they are sent (this is autoack in native Rabbit broker terms). If AcknowledgeMode.NONE then the channel cannot be transactional (so the container will fail on start up if that flag is accidentally set).

Enum values:

  • NONE
  • MANUAL
  • AUTO
 

AcknowledgeMode

asyncConsumer (consumer)

Whether the consumer processes the Exchange asynchronously. If enabled then the consumer may pickup the next message from the queue, while the previous message is being processed asynchronously (by the Asynchronous Routing Engine). This means that messages may be processed not 100% strictly in order. If disabled (as default) then the Exchange is fully processed before the consumer will pickup the next message from the queue.

false

boolean

autoDeclare (consumer)

Specifies whether the consumer should auto declare binding between exchange, queue and routing key when starting.

true

boolean

autoStartup (consumer)

Specifies whether the consumer container should auto-startup.

true

boolean

deadLetterExchange (consumer)

The name of the dead letter exchange.

 

String

deadLetterExchangeType (consumer)

The type of the dead letter exchange.

Enum values:

  • direct
  • fanout
  • headers
  • topic

direct

String

deadLetterQueue (consumer)

The name of the dead letter queue.

 

String

deadLetterRoutingKey (consumer)

The routing key for the dead letter exchange.

 

String

exchangeType (consumer)

The type of the exchange.

Enum values:

  • direct
  • fanout
  • headers
  • topic

direct

String

exclusive (consumer)

Set to true for an exclusive consumer.

false

boolean

maximumRetryAttempts (consumer)

How many times a Rabbitmq consumer will retry the same message if Camel failed to process the message.

5

int

noLocal (consumer)

Set to true for an no-local consumer.

false

boolean

queues (consumer)

The queue(s) to use for consuming messages. Multiple queue names can be separated by comma. If none has been configured then Camel will generate an unique id as the queue name for the consumer.

 

String

rejectAndDontRequeue (consumer)

Whether a Rabbitmq consumer should reject the message without requeuing. This enables failed messages to be sent to a Dead Letter Exchange/Queue, if the broker is so configured.

true

boolean

retryDelay (consumer)

Delay in msec a Rabbitmq consumer will wait before redelivering a message that Camel failed to process.

1000

int

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

concurrentConsumers (consumer (advanced))

The number of consumers.

 

Integer

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

maxConcurrentConsumers (consumer (advanced))

The maximum number of consumers (available only with SMLC).

 

Integer

messageListenerContainerType (consumer (advanced))

The type of the MessageListenerContainer.

Enum values:

  • DMLC
  • SMLC

DMLC

String

prefetchCount (consumer (advanced))

Tell the broker how many messages to send in a single request. Often this can be set quite high to improve throughput.

 

Integer

retry (consumer (advanced))

Custom retry configuration to use. If this is configured then the other settings such as maximumRetryAttempts for retry are not in use.

 

RetryOperationsInterceptor

replyTimeout (producer)

Specify the timeout in milliseconds to be used when waiting for a reply message when doing request/reply messaging. The default value is 5 seconds. A negative value indicates an indefinite timeout.

5000

long

usePublisherConnection (producer)

Use a separate connection for publishers and consumers.

false

boolean

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

args (advanced)

Specify arguments for configuring the different RabbitMQ concepts, a different prefix is required for each element: arg.consumer. arg.exchange. arg.queue. arg.binding. arg.dlq.exchange. arg.dlq.queue. arg.dlq.binding. For example to declare a queue with message ttl argument: args=arg.queue.x-message-ttl=60000.

 

Map

messageConverter (advanced)

To use a custom MessageConverter so you can be in control how to map to/from a org.springframework.amqp.core.Message.

 

MessageConverter

messagePropertiesConverter (advanced)

To use a custom MessagePropertiesConverter so you can be in control how to map to/from a org.springframework.amqp.core.MessageProperties.

 

MessagePropertiesConverter

synchronous (advanced)

Sets whether synchronous processing should be strictly used.

false

boolean

125.6. Message Headers

The Spring RabbitMQ component supports 2 message headers that are listed below:

NameDescriptionDefaultType

CamelSpringRabbitmqRoutingOverrideKey (common)

Constant: ROUTING_OVERRIDE_KEY

The exchange key.

 

String

CamelSpringRabbitmqExchangeOverrideName (common)

Constant: EXCHANGE_OVERRIDE_NAME

The exchange name.

 

String

125.7. Using a connection factory

To connect to RabbitMQ you must setup a ConnectionFactory (same as JMS) with the login details as described below.

It is recommended to use CachingConnectionFactory from spring-rabbit as it comes with connection pooling out of the box.

<bean id="rabbitConnectionFactory" class="org.springframework.amqp.rabbit.connection.CachingConnectionFactory">
  <property name="uri" value="amqp://lolcalhost:5672"/>
</bean>

The ConnectionFactory is auto-detected by default, so you can just execute it.

<camelContext>
  <route>
    <from uri="direct:cheese"/>
    <to uri="spring-rabbitmq:foo?routingKey=cheese"/>
  </route>
</camelContext>

125.8. Default Exchange Name

To use default exchange name (which would be an empty exchange name in RabbitMQ) you must use default as name in the endpoint uri, like:

to("spring-rabbitmq:default?routingKey=foo")

125.9. Auto declare exchanges, queues and bindings

Before you can send or receive messages from RabbitMQ, you must first set up the exchanges, queues and bindings.

In development mode, Camel can automatically do this. You can enable this by setting autoDeclare=true on the SpringRabbitMQComponent.

Then Spring RabbitMQ automatically declares the elements and sets up the binding between the exchange, queue and routing keys.

The elements can be configured using the multi-valued args option.

For example to specify the queue as durable and exclusive, you can configure the endpoint uri with arg.queue.durable=true&arg.queue.exclusive=true.

Exchanges

OptionTypeDescriptionDefault

autoDelete

boolean

True if the server should delete the exchange when it is no longer in use (if all bindings are deleted).

false

durable

boolean

A durable exchange will survive a server restart.

true

You can also configure any additional x- arguments. See details in the RabbitMQ documentation.

Queues

OptionTypeDescriptionDefault

autoDelete

boolean

True if the server should delete the exchange when it is no longer in use (if all bindings are deleted).

false

durable

boolean

A durable queue will survive a server restart.

false

exclusive

boolean

Whether the queue is exclusive

false

x-dead-letter-exchange

String

The name of the dead letter exchange. If none configured then the component configured value is used.

 

x-dead-letter-routing-key

String

The routing key for the dead letter exchange. If none configured then the component configured value is used.

 

You can also configure any additional x- arguments, such as the message time to live using x-message-ttl, and many others. See details in the RabbitMQ documentation.

125.10. Mapping from Camel to RabbitMQ

The message body is mapped from Camel Message body to a byte[] which is the type that RabbitMQ uses for message body. Camel uses its type converter to convert the message body to byte array.

Spring Rabbit comes out of the box with support for mapping Java serialized objects but Camel Spring RabbitMQ does not support this due to security vulnerabilities and using Java objects is a bad design as it enforces strong coupling.

Custom message headers is mapped from Camel Message headers to RabbitMQ headers. This behaviour can be customized by configuring a new implementation of HeaderFilterStrategy on the Camel component.

125.11. Request / Reply

Request and reply messaging is supported using RabbitMQ direct reply-to.

The example below does request/reply, where the message is sent using the cheese exchange name and routing key foo.bar, which is being consumed by the 2nd Camel route, that prepends the message with `Hello `, and then sends back the message.

So if we send World as message body to direct:start then, we can see the message being logged

  • log:request ⇒ World
  • log:input ⇒ World
  • log:response ⇒ Hello World
from("direct:start")
    .to("log:request")
    .to(ExchangePattern.InOut, "spring-rabbitmq:cheese?routingKey=foo.bar")
    .to("log:response");

from("spring-rabbitmq:cheese?queues=myqueue&routingKey=foo.bar")
    .to("log:input")
    .transform(body().prepend("Hello "));

125.12. Reuse endpoint and send to different destinations computed at runtime

If you need to send messages to a lot of different RabbitMQ exchanges, you must reuse an endpoint and specify the real destination in a message header. This allows Camel to reuse the same endpoint, but send to different exchanges. This greatly reduces the number of endpoints created and economizes on memory and thread resources.

Note

Using toD is easier than specifying the dynamic destination with headers.

You can specify using the following headers:

HeaderTypeDescription

CamelSpringRabbitmqExchangeOverrideName

String

The exchange name.

CamelSpringRabbitmqRoutingOverrideKey

String

The routing key.

For example, the following route shows how you can compute a destination at run time and use it to override the exchange appearing in the endpoint URL:

from("file://inbox")
  .to("bean:computeDestination")
  .to("spring-rabbitmq:dummy");

The exchange name, dummy, is just a placeholder. It must be provided as part of the RabbitMQ endpoint URL, but it is ignored in this example.

In the computeDestination bean, specify the real destination by setting the CamelRabbitmqExchangeOverrideName header as follows:

public void setExchangeHeader(Exchange exchange) {
   String region = ....
   exchange.getIn().setHeader("CamelSpringRabbitmqExchangeOverrideName", "order-" + region);
}

Camel reads this header and uses it as the exchange name instead of the one configured on the endpoint. So, in this example Camel sends the message to spring-rabbitmq:order-emea, assuming the region value was emea.

The producer removes both CamelSpringRabbitmqExchangeOverrideName and CamelSpringRabbitmqRoutingOverrideKey headers from the exchange and do not propagate them to the created Rabbitmq message in order to avoid the accidental loops in the routes (in scenarios when the message is forwarded to another RabbitMQ endpoint).

125.13. Using toD

If you need to send messages to a lot of different exchanges, you must reuse an endpoint and specify the dynamic destinations with simple language using toD.

For example, you need to send messages to the exchange with order types, then you can use toD as follows:

from("direct:order")
  .toD("spring-rabbit:order-${header.orderType}");

125.14. Spring Boot Auto-Configuration

The component supports 30 options that are listed below.

NameDescriptionDefaultType

camel.component.spring-rabbitmq.allow-null-body

Whether to allow sending messages with no body. If this option is false and the message body is null, then an MessageConversionException is thrown.

false

Boolean

camel.component.spring-rabbitmq.amqp-admin

Optional AMQP Admin service to use for auto declaring elements (queues, exchanges, bindings). The option is a org.springframework.amqp.core.AmqpAdmin type.

 

AmqpAdmin

camel.component.spring-rabbitmq.auto-declare

Specifies whether the consumer should auto declare binding between exchange, queue and routing key when starting. Enabling this can be good for development to make it easy to standup exchanges, queues and bindings on the broker.

false

Boolean

camel.component.spring-rabbitmq.auto-startup

Specifies whether the consumer container should auto-startup.

true

Boolean

camel.component.spring-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.spring-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.spring-rabbitmq.concurrent-consumers

The number of consumers.

1

Integer

camel.component.spring-rabbitmq.connection-factory

The connection factory to be use. A connection factory must be configured either on the component or endpoint. The option is a org.springframework.amqp.rabbit.connection.ConnectionFactory type.

 

ConnectionFactory

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

The name of the dead letter exchange.

 

String

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

The type of the dead letter exchange.

direct

String

camel.component.spring-rabbitmq.dead-letter-queue

The name of the dead letter queue.

 

String

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

The routing key for the dead letter exchange.

 

String

camel.component.spring-rabbitmq.enabled

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

 

Boolean

camel.component.spring-rabbitmq.error-handler

To use a custom ErrorHandler for handling exceptions from the message listener (consumer). The option is a org.springframework.util.ErrorHandler type.

 

ErrorHandler

camel.component.spring-rabbitmq.header-filter-strategy

To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter header to and from Camel message. The option is a org.apache.camel.spi.HeaderFilterStrategy type.

 

HeaderFilterStrategy

camel.component.spring-rabbitmq.ignore-declaration-exceptions

Switch on ignore exceptions such as mismatched properties when declaring.

false

Boolean

camel.component.spring-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.spring-rabbitmq.listener-container-factory

To use a custom factory for creating and configuring ListenerContainer to be used by the consumer for receiving messages. The option is a org.apache.camel.component.springrabbit.ListenerContainerFactory type.

 

ListenerContainerFactory

camel.component.spring-rabbitmq.max-concurrent-consumers

The maximum number of consumers (available only with SMLC).

 

Integer

camel.component.spring-rabbitmq.maximum-retry-attempts

How many times a Rabbitmq consumer will retry the same message if Camel failed to process the message.

5

Integer

camel.component.spring-rabbitmq.message-converter

To use a custom MessageConverter so you can be in control how to map to/from a org.springframework.amqp.core.Message. The option is a org.springframework.amqp.support.converter.MessageConverter type.

 

MessageConverter

camel.component.spring-rabbitmq.message-listener-container-type

The type of the MessageListenerContainer.

DMLC

String

camel.component.spring-rabbitmq.message-properties-converter

To use a custom MessagePropertiesConverter so you can be in control how to map to/from a org.springframework.amqp.core.MessageProperties. The option is a org.apache.camel.component.springrabbit.MessagePropertiesConverter type.

 

MessagePropertiesConverter

camel.component.spring-rabbitmq.prefetch-count

Tell the broker how many messages to send to each consumer in a single request. Often this can be set quite high to improve throughput.

250

Integer

camel.component.spring-rabbitmq.reject-and-dont-requeue

Whether a Rabbitmq consumer should reject the message without requeuing. This enables failed messages to be sent to a Dead Letter Exchange/Queue, if the broker is so configured.

true

Boolean

camel.component.spring-rabbitmq.reply-timeout

Specify the timeout in milliseconds to be used when waiting for a reply message when doing request/reply messaging. The default value is 5 seconds. A negative value indicates an indefinite timeout. The option is a long type.

5000

Long

camel.component.spring-rabbitmq.retry

Custom retry configuration to use. If this is configured then the other settings such as maximumRetryAttempts for retry are not in use. The option is a org.springframework.retry.interceptor.RetryOperationsInterceptor type.

 

RetryOperationsInterceptor

camel.component.spring-rabbitmq.retry-delay

Delay in msec a Rabbitmq consumer will wait before redelivering a message that Camel failed to process.

1000

Integer

camel.component.spring-rabbitmq.shutdown-timeout

The time to wait for workers in milliseconds after the container is stopped. If any workers are active when the shutdown signal comes they will be allowed to finish processing as long as they can finish within this timeout. The option is a long type.

5000

Long

camel.component.spring-rabbitmq.test-connection-on-startup

Specifies whether to test the connection on startup. This ensures that when Camel starts that all the JMS consumers have a valid connection to the JMS broker. If a connection cannot be granted then Camel throws an exception on startup. This ensures that Camel is not started with failed connections. The JMS producers is tested as well.

false

Boolean

Red Hat logoGithubRedditYoutubeTwitter

Apprendre

Essayez, achetez et vendez

Communautés

À propos de la documentation Red Hat

Nous aidons les utilisateurs de Red Hat à innover et à atteindre leurs objectifs grâce à nos produits et services avec un contenu auquel ils peuvent faire confiance.

Rendre l’open source plus inclusif

Red Hat s'engage à remplacer le langage problématique dans notre code, notre documentation et nos propriétés Web. Pour plus de détails, consultez leBlog Red Hat.

À propos de Red Hat

Nous proposons des solutions renforcées qui facilitent le travail des entreprises sur plusieurs plates-formes et environnements, du centre de données central à la périphérie du réseau.

© 2024 Red Hat, Inc.