You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2021/03/16 15:40:31 UTC

[camel-spring-boot] 01/02: CAMEL-16358: camel-spring-rabbitmq - Configure consumer retry strategies more easily

This is an automated email from the ASF dual-hosted git repository.

davsclaus pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/camel-spring-boot.git

commit acca17aeeceed5387042395ecb0b9fff041ef8f9
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Tue Mar 16 16:39:41 2021 +0100

    CAMEL-16358: camel-spring-rabbitmq - Configure consumer retry strategies more easily
---
 .../catalog/components/spring-rabbitmq.json        | 11 +++-
 .../src/main/docs/spring-rabbitmq-starter.adoc     |  7 ++-
 .../SpringRabbitMQComponentConfiguration.java      | 71 ++++++++++++++++++++++
 .../SpringRabbitMQComponentConverter.java          |  2 +
 4 files changed, 89 insertions(+), 2 deletions(-)

diff --git a/catalog/camel-catalog-provider-springboot/src/main/resources/org/apache/camel/springboot/catalog/components/spring-rabbitmq.json b/catalog/camel-catalog-provider-springboot/src/main/resources/org/apache/camel/springboot/catalog/components/spring-rabbitmq.json
index 6a4c1dc..9d91193 100644
--- a/catalog/camel-catalog-provider-springboot/src/main/resources/org/apache/camel/springboot/catalog/components/spring-rabbitmq.json
+++ b/catalog/camel-catalog-provider-springboot/src/main/resources/org/apache/camel/springboot/catalog/components/spring-rabbitmq.json
@@ -32,14 +32,19 @@
     "deadLetterExchangeType": { "kind": "property", "displayName": "Dead Letter Exchange Type", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "enum": [ "direct", "fanout", "headers", "topic" ], "deprecated": false, "autowired": false, "secret": false, "defaultValue": "direct", "description": "The type of the dead letter exchange" },
     "deadLetterQueue": { "kind": "property", "displayName": "Dead Letter Queue", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "deprecated": false, "autowired": false, "secret": false, "description": "The name of the dead letter queue" },
     "deadLetterRoutingKey": { "kind": "property", "displayName": "Dead Letter Routing Key", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "deprecated": false, "autowired": false, "secret": false, "description": "The routing key for the dead letter exchange" },
+    "maximumRetryAttempts": { "kind": "property", "displayName": "Maximum Retry Attempts", "group": "consumer", "label": "consumer", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 5, "description": "How many times a Rabbitmq consumer will retry the same message if Camel failed to process the message" },
+    "rejectAndDontRequeue": { "kind": "property", "displayName": "Reject And Dont Requeue", "group": "consumer", "label": "consumer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": true, "description": "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." },
+    "retryDelay": { "kind": "property", "displayName": "Retry Delay", "group": "consumer", "label": "consumer", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 1000, "description": "Delay in msec a Rabbitmq consumer will wait before redelivering a message that Camel failed to process" },
     "concurrentConsumers": { "kind": "property", "displayName": "Concurrent Consumers", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 1, "description": "The number of consumers" },
     "errorHandler": { "kind": "property", "displayName": "Error Handler", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.springframework.util.ErrorHandler", "deprecated": false, "autowired": false, "secret": false, "description": "To use a custom ErrorHandler for handling exceptions from the message listener (consumer)" },
     "listenerContainerFactory": { "kind": "property", "displayName": "Listener Container Factory", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.apache.camel.component.springrabbit.ListenerContainerFactory", "deprecated": false, "autowired": false, "secret": false, "description": "To use a custom factory for creating and configuring ListenerContainer to be used by the consumer for receiving messages" },
     "maxConcurrentConsumers": { "kind": "property", "displayName": "Max Concurrent Consumers", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "java.lang.Integer", "deprecated": false, "autowired": false, "secret": false, "description": "The maximum number of consumers (available only with SMLC)" },
     "messageListenerContainerType": { "kind": "property", "displayName": "Message Listener Container Type", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "string", "javaType": "java.lang.String", "enum": [ "DMLC", "SMLC" ], "deprecated": false, "autowired": false, "secret": false, "defaultValue": "DMLC", "description": "The type of the MessageListenerContainer" },
     "prefetchCount": { "kind": "property", "displayName": "Prefetch Count", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 250, "description": "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." },
+    "retry": { "kind": "property", "displayName": "Retry", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.springframework.retry.interceptor.RetryOperationsInterceptor", "deprecated": false, "autowired": false, "secret": false, "description": "Custom retry configuration to use. If this is configured then the other settings such as maximumRetryAttempts for retry are not in use." },
     "shutdownTimeout": { "kind": "property", "displayName": "Shutdown Timeout", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "duration", "javaType": "long", "deprecated": false, "autowired": false, "secret": false, "defaultValue": "5000", "description": "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 c [...]
     "lazyStartProducer": { "kind": "property", "displayName": "Lazy Start Producer", "group": "producer", "label": "producer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "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 star [...]
+    "replyTimeout": { "kind": "property", "displayName": "Reply Timeout", "group": "producer", "label": "producer", "required": false, "type": "duration", "javaType": "long", "deprecated": false, "autowired": false, "secret": false, "defaultValue": "5000", "description": "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." },
     "autowiredEnabled": { "kind": "property", "displayName": "Autowired Enabled", "group": "advanced", "label": "advanced", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": true, "description": "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 t [...]
     "ignoreDeclarationExceptions": { "kind": "property", "displayName": "Ignore Declaration Exceptions", "group": "advanced", "label": "advanced", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "Switch on ignore exceptions such as mismatched properties when declaring" },
     "messageConverter": { "kind": "property", "displayName": "Message Converter", "group": "advanced", "label": "advanced", "required": false, "type": "object", "javaType": "org.springframework.amqp.support.converter.MessageConverter", "deprecated": false, "autowired": false, "secret": false, "description": "To use a custom MessageConverter so you can be in control how to map to\/from a org.springframework.amqp.core.Message." },
@@ -63,14 +68,18 @@
     "deadLetterRoutingKey": { "kind": "parameter", "displayName": "Dead Letter Routing Key", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "deprecated": false, "autowired": false, "secret": false, "description": "The routing key for the dead letter exchange" },
     "exchangeType": { "kind": "parameter", "displayName": "Exchange Type", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "enum": [ "direct", "fanout", "headers", "topic" ], "deprecated": false, "autowired": false, "secret": false, "defaultValue": "direct", "description": "The type of the exchange" },
     "exclusive": { "kind": "parameter", "displayName": "Exclusive", "group": "consumer", "label": "consumer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "Set to true for an exclusive consumer" },
+    "maximumRetryAttempts": { "kind": "parameter", "displayName": "Maximum Retry Attempts", "group": "consumer", "label": "consumer", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 5, "description": "How many times a Rabbitmq consumer will retry the same message if Camel failed to process the message" },
     "noLocal": { "kind": "parameter", "displayName": "No Local", "group": "consumer", "label": "consumer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "Set to true for an no-local consumer" },
-    "queues": { "kind": "parameter", "displayName": "Queues", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "deprecated": false, "deprecationNote": "", "autowired": false, "secret": false, "description": "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." },
+    "queues": { "kind": "parameter", "displayName": "Queues", "group": "consumer", "label": "consumer", "required": false, "type": "string", "javaType": "java.lang.String", "deprecated": false, "autowired": false, "secret": false, "description": "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." },
+    "rejectAndDontRequeue": { "kind": "parameter", "displayName": "Reject And Dont Requeue", "group": "consumer", "label": "consumer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": true, "description": "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." },
+    "retryDelay": { "kind": "parameter", "displayName": "Retry Delay", "group": "consumer", "label": "consumer", "required": false, "type": "integer", "javaType": "int", "deprecated": false, "autowired": false, "secret": false, "defaultValue": 1000, "description": "Delay in msec a Rabbitmq consumer will wait before redelivering a message that Camel failed to process" },
     "concurrentConsumers": { "kind": "parameter", "displayName": "Concurrent Consumers", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "java.lang.Integer", "deprecated": false, "autowired": false, "secret": false, "description": "The number of consumers" },
     "exceptionHandler": { "kind": "parameter", "displayName": "Exception Handler", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.apache.camel.spi.ExceptionHandler", "optionalPrefix": "consumer.", "deprecated": false, "autowired": false, "secret": false, "description": "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 con [...]
     "exchangePattern": { "kind": "parameter", "displayName": "Exchange Pattern", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.apache.camel.ExchangePattern", "enum": [ "InOnly", "InOut", "InOptionalOut" ], "deprecated": false, "autowired": false, "secret": false, "description": "Sets the exchange pattern when the consumer creates an exchange." },
     "maxConcurrentConsumers": { "kind": "parameter", "displayName": "Max Concurrent Consumers", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "java.lang.Integer", "deprecated": false, "autowired": false, "secret": false, "description": "The maximum number of consumers (available only with SMLC)" },
     "messageListenerContainerType": { "kind": "parameter", "displayName": "Message Listener Container Type", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "string", "javaType": "java.lang.String", "enum": [ "DMLC", "SMLC" ], "deprecated": false, "autowired": false, "secret": false, "defaultValue": "DMLC", "description": "The type of the MessageListenerContainer" },
     "prefetchCount": { "kind": "parameter", "displayName": "Prefetch Count", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "integer", "javaType": "java.lang.Integer", "deprecated": false, "autowired": false, "secret": false, "description": "Tell the broker how many messages to send in a single request. Often this can be set quite high to improve throughput." },
+    "retry": { "kind": "parameter", "displayName": "Retry", "group": "consumer (advanced)", "label": "consumer,advanced", "required": false, "type": "object", "javaType": "org.springframework.retry.interceptor.RetryOperationsInterceptor", "deprecated": false, "autowired": false, "secret": false, "description": "Custom retry configuration to use. If this is configured then the other settings such as maximumRetryAttempts for retry are not in use." },
     "lazyStartProducer": { "kind": "parameter", "displayName": "Lazy Start Producer", "group": "producer", "label": "producer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "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 sta [...]
     "replyTimeout": { "kind": "parameter", "displayName": "Reply Timeout", "group": "producer", "label": "producer", "required": false, "type": "duration", "javaType": "long", "deprecated": false, "autowired": false, "secret": false, "defaultValue": "5000", "description": "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." },
     "usePublisherConnection": { "kind": "parameter", "displayName": "Use Publisher Connection", "group": "producer", "label": "producer", "required": false, "type": "boolean", "javaType": "boolean", "deprecated": false, "autowired": false, "secret": false, "defaultValue": false, "description": "Use a separate connection for publishers and consumers" },
diff --git a/components-starter/camel-spring-rabbitmq-starter/src/main/docs/spring-rabbitmq-starter.adoc b/components-starter/camel-spring-rabbitmq-starter/src/main/docs/spring-rabbitmq-starter.adoc
index 89d4cb6..223e1ae 100644
--- a/components-starter/camel-spring-rabbitmq-starter/src/main/docs/spring-rabbitmq-starter.adoc
+++ b/components-starter/camel-spring-rabbitmq-starter/src/main/docs/spring-rabbitmq-starter.adoc
@@ -17,7 +17,7 @@ When using spring-rabbitmq with Spring Boot make sure to use the following Maven
 ----
 
 
-The component supports 24 options, which are listed below.
+The component supports 29 options, which are listed below.
 
 
 
@@ -42,10 +42,15 @@ The component supports 24 options, which are listed below.
 | *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 proc [...]
 | *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
 |===
diff --git a/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConfiguration.java b/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConfiguration.java
index a38c317..39bdc27 100644
--- a/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConfiguration.java
+++ b/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConfiguration.java
@@ -25,6 +25,7 @@ import org.springframework.amqp.core.AmqpAdmin;
 import org.springframework.amqp.rabbit.connection.ConnectionFactory;
 import org.springframework.amqp.support.converter.MessageConverter;
 import org.springframework.boot.context.properties.ConfigurationProperties;
+import org.springframework.retry.interceptor.RetryOperationsInterceptor;
 import org.springframework.util.ErrorHandler;
 
 /**
@@ -100,6 +101,22 @@ public class SpringRabbitMQComponentConfiguration
      */
     private String deadLetterRoutingKey;
     /**
+     * How many times a Rabbitmq consumer will retry the same message if Camel
+     * failed to process the message
+     */
+    private Integer maximumRetryAttempts = 5;
+    /**
+     * 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.
+     */
+    private Boolean rejectAndDontRequeue = true;
+    /**
+     * Delay in msec a Rabbitmq consumer will wait before redelivering a message
+     * that Camel failed to process
+     */
+    private Integer retryDelay = 1000;
+    /**
      * The number of consumers
      */
     private Integer concurrentConsumers = 1;
@@ -129,6 +146,13 @@ public class SpringRabbitMQComponentConfiguration
      */
     private Integer prefetchCount = 250;
     /**
+     * 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.
+     */
+    private RetryOperationsInterceptor retry;
+    /**
      * 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
@@ -147,6 +171,13 @@ public class SpringRabbitMQComponentConfiguration
      */
     private Boolean lazyStartProducer = false;
     /**
+     * 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.
+     */
+    private Long replyTimeout = 5000L;
+    /**
      * 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
@@ -259,6 +290,30 @@ public class SpringRabbitMQComponentConfiguration
         this.deadLetterRoutingKey = deadLetterRoutingKey;
     }
 
+    public Integer getMaximumRetryAttempts() {
+        return maximumRetryAttempts;
+    }
+
+    public void setMaximumRetryAttempts(Integer maximumRetryAttempts) {
+        this.maximumRetryAttempts = maximumRetryAttempts;
+    }
+
+    public Boolean getRejectAndDontRequeue() {
+        return rejectAndDontRequeue;
+    }
+
+    public void setRejectAndDontRequeue(Boolean rejectAndDontRequeue) {
+        this.rejectAndDontRequeue = rejectAndDontRequeue;
+    }
+
+    public Integer getRetryDelay() {
+        return retryDelay;
+    }
+
+    public void setRetryDelay(Integer retryDelay) {
+        this.retryDelay = retryDelay;
+    }
+
     public Integer getConcurrentConsumers() {
         return concurrentConsumers;
     }
@@ -309,6 +364,14 @@ public class SpringRabbitMQComponentConfiguration
         this.prefetchCount = prefetchCount;
     }
 
+    public RetryOperationsInterceptor getRetry() {
+        return retry;
+    }
+
+    public void setRetry(RetryOperationsInterceptor retry) {
+        this.retry = retry;
+    }
+
     public Long getShutdownTimeout() {
         return shutdownTimeout;
     }
@@ -325,6 +388,14 @@ public class SpringRabbitMQComponentConfiguration
         this.lazyStartProducer = lazyStartProducer;
     }
 
+    public Long getReplyTimeout() {
+        return replyTimeout;
+    }
+
+    public void setReplyTimeout(Long replyTimeout) {
+        this.replyTimeout = replyTimeout;
+    }
+
     public Boolean getAutowiredEnabled() {
         return autowiredEnabled;
     }
diff --git a/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConverter.java b/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConverter.java
index c6da166..e303b1a 100644
--- a/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConverter.java
+++ b/components-starter/camel-spring-rabbitmq-starter/src/main/java/org/apache/camel/component/springrabbit/springboot/SpringRabbitMQComponentConverter.java
@@ -45,6 +45,7 @@ public class SpringRabbitMQComponentConverter implements GenericConverter {
         answer.add(new ConvertiblePair(String.class, org.springframework.amqp.rabbit.connection.ConnectionFactory.class));
         answer.add(new ConvertiblePair(String.class, org.springframework.util.ErrorHandler.class));
         answer.add(new ConvertiblePair(String.class, org.apache.camel.component.springrabbit.ListenerContainerFactory.class));
+        answer.add(new ConvertiblePair(String.class, org.springframework.retry.interceptor.RetryOperationsInterceptor.class));
         answer.add(new ConvertiblePair(String.class, org.springframework.amqp.support.converter.MessageConverter.class));
         answer.add(new ConvertiblePair(String.class, org.apache.camel.component.springrabbit.MessagePropertiesConverter.class));
         answer.add(new ConvertiblePair(String.class, org.apache.camel.spi.HeaderFilterStrategy.class));
@@ -68,6 +69,7 @@ public class SpringRabbitMQComponentConverter implements GenericConverter {
             case "org.springframework.amqp.rabbit.connection.ConnectionFactory": return applicationContext.getBean(ref, org.springframework.amqp.rabbit.connection.ConnectionFactory.class);
             case "org.springframework.util.ErrorHandler": return applicationContext.getBean(ref, org.springframework.util.ErrorHandler.class);
             case "org.apache.camel.component.springrabbit.ListenerContainerFactory": return applicationContext.getBean(ref, org.apache.camel.component.springrabbit.ListenerContainerFactory.class);
+            case "org.springframework.retry.interceptor.RetryOperationsInterceptor": return applicationContext.getBean(ref, org.springframework.retry.interceptor.RetryOperationsInterceptor.class);
             case "org.springframework.amqp.support.converter.MessageConverter": return applicationContext.getBean(ref, org.springframework.amqp.support.converter.MessageConverter.class);
             case "org.apache.camel.component.springrabbit.MessagePropertiesConverter": return applicationContext.getBean(ref, org.apache.camel.component.springrabbit.MessagePropertiesConverter.class);
             case "org.apache.camel.spi.HeaderFilterStrategy": return applicationContext.getBean(ref, org.apache.camel.spi.HeaderFilterStrategy.class);