- secretPropertyNames() - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpointUriFactory
-
- sent(Connection, byte[], String) - Method in interface org.apache.camel.component.rabbitmq.reply.MessageSentCallback
-
Callback when the message has been sent.
- sent(Connection, byte[], String) - Method in class org.apache.camel.component.rabbitmq.reply.UseMessageIdAsCorrelationIdMessageSentCallback
-
- SERIALIZE_HEADER - Static variable in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setAdditionalHeaders(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Map of additional headers.
- setAdditionalHeaders(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Map of additional headers.
- setAdditionalHeaders(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQMessageConverter
-
- setAdditionalProperties(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Map of additional properties.
- setAdditionalProperties(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Map of additional properties.
- setAdditionalProperties(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQMessageConverter
-
- setAddresses(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses.
- setAddresses(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses.
- setAllowCustomHeaders(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Allow pass custom values to header
- setAllowCustomHeaders(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQMessageConverter
-
- setAllowMessageBodySerialization(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Whether to allow Java serialization of the message body or not.
- setAllowNullHeaders(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setAllowNullHeaders(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setAllowNullHeaders(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQMessageConverter
-
- setArgs(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
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/queue?args=arg.queue.x-message-ttl=60000
- setArgs(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
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/queue?args=arg.queue.x-message-ttl=60000
- setAutoAck(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If messages should be auto acknowledged
- setAutoAck(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If messages should be auto acknowledged
- setAutoDelete(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If it is true, the exchange will be deleted when it is no longer in use
- setAutoDelete(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If it is true, the exchange will be deleted when it is no longer in use
- setAutoDetectConnectionFactory(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Whether to auto-detect looking up RabbitMQ connection factory from the registry.
- setAutomaticRecoveryEnabled(Boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Enables connection automatic recovery (uses connection implementation that performs automatic recovery when
connection shutdown is not initiated by the application)
- setAutomaticRecoveryEnabled(Boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Enables connection automatic recovery (uses connection implementation that performs automatic recovery when
existing connection has failures)
- setBridgeEndpoint(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If the bridgeEndpoint is true, the producer will ignore the message header of "rabbitmq.EXCHANGE_NAME" and
"rabbitmq.ROUTING_KEY"
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.rabbitmq.RabbitMQSendDynamicAware
-
- setChannelPoolMaxSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setChannelPoolMaxSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setChannelPoolMaxWait(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Set the maximum number of milliseconds to wait for a channel from the pool
- setChannelPoolMaxWait(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Set the maximum number of milliseconds to wait for a channel from the pool
- setClientProperties(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Connection client properties (client info used in negotiating with the server)
- setClientProperties(Map<String, Object>) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Connection client properties (client info used in negotiating with the server)
- setCloseTimeout(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQProducer
-
- setConcurrentConsumers(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Number of concurrent consumers when consuming from broker.
- setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
To use a custom RabbitMQ connection factory.
- setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
To use a custom RabbitMQ connection factory.
- setConnectionFactoryExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Custom rabbitmq ExceptionHandler for ConnectionFactory
- setConnectionFactoryExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Custom rabbitmq ExceptionHandler for ConnectionFactory
- setConnectionTimeout(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Connection timeout
- setConnectionTimeout(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Connection timeout
- setConsumerTag(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Specify a client-generated consumer tag to establish context when invoking the consume operation
- setDeadLetterExchange(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The name of the dead letter exchange
- setDeadLetterExchange(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The name of the dead letter exchange
- setDeadLetterExchangeType(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The type of the dead letter exchange
- setDeadLetterExchangeType(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The type of the dead letter exchange
- setDeadLetterQueue(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The name of the dead letter queue
- setDeadLetterQueue(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The name of the dead letter queue
- setDeadLetterRoutingKey(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The routing key for the dead letter exchange
- setDeadLetterRoutingKey(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The routing key for the dead letter exchange
- setDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If the option is true, camel declare the exchange and queue name and bind them together.
- setDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If the option is true, camel declare the exchange and queue name and bind them together.
- setDurable(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If we are declaring a durable exchange (the exchange will survive a server restart)
- setDurable(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If we are declaring a durable exchange (the exchange will survive a server restart)
- setEndpoint(RabbitMQEndpoint) - Method in interface org.apache.camel.component.rabbitmq.reply.ReplyManager
-
- setEndpoint(RabbitMQEndpoint) - Method in class org.apache.camel.component.rabbitmq.reply.ReplyManagerSupport
-
- setExchangeName(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The exchange name determines the exchange to which the produced messages will be sent to.
- setExchangeType(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The exchange type such as direct or topic.
- setExclusive(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.
- setExclusive(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.
- setExclusiveConsumer(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Request exclusive access to the queue (meaning only this consumer can access the queue).
- setExclusiveConsumer(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Request exclusive access to the queue (meaning only this consumer can access the queue).
- setGuaranteedDeliveries(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setGuaranteedDeliveries(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setHostname(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The hostname of the running RabbitMQ instance or cluster.
- setHostname(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The hostname of the running rabbitmq instance or cluster.
- setImmediate(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
This flag tells the server how to react if the message cannot be routed to a queue consumer immediately.
- setImmediate(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
This flag tells the server how to react if the message cannot be routed to a queue consumer immediately.
- setMandatory(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
This flag tells the server how to react if the message cannot be routed to a queue.
- setMandatory(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
This flag tells the server how to react if the message cannot be routed to a queue.
- setNetworkRecoveryInterval(Integer) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Network recovery interval in milliseconds (interval used when recovering from network failure)
- setNetworkRecoveryInterval(Integer) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Network recovery interval in milliseconds (interval used when recovering from network failure)
- setPassive(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Passive queues depend on the queue already to be available at RabbitMQ.
- setPassive(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Passive queues depend on the queue already to be available at RabbitMQ.
- setPassword(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Password for authenticated access
- setPassword(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Password for authenticated access
- setPortNumber(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Port number for the host with the running rabbitmq instance or cluster.
- setPortNumber(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Port number for the host with the running rabbitmq instance or cluster.
- setPrefetchCount(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The maximum number of messages that the server will deliver, 0 if unlimited.
- setPrefetchCount(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The maximum number of messages that the server will deliver, 0 if unlimited.
- setPrefetchEnabled(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Enables the quality of service on the RabbitMQConsumer side.
- setPrefetchEnabled(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Enables the quality of service on the RabbitMQConsumer side.
- setPrefetchGlobal(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
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
- setPrefetchGlobal(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
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
- setPrefetchSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited.
- setPrefetchSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited.
- setPublisherAcknowledgements(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setPublisherAcknowledgements(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setPublisherAcknowledgementsTimeout(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setPublisherAcknowledgementsTimeout(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setQueue(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The queue to receive messages from
- setRecoverFromDeclareException(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Decides whether an exception during declaration of exchanges or queues is recoverable or not.
- setRecoverFromDeclareException(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setReplyTo(String) - Method in interface org.apache.camel.component.rabbitmq.reply.ReplyManager
-
Sets the reply to queue the manager should listen for replies.
- setReplyTo(String) - Method in class org.apache.camel.component.rabbitmq.reply.ReplyManagerSupport
-
- setRequestedChannelMax(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Connection requested channel max (max number of channels offered)
- setRequestedChannelMax(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Connection requested channel max (max number of channels offered)
- setRequestedFrameMax(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Connection requested frame max (max size of frame offered)
- setRequestedFrameMax(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Connection requested frame max (max size of frame offered)
- setRequestedHeartbeat(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Connection requested heartbeat (heart-beat in seconds offered)
- setRequestedHeartbeat(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Connection requested heartbeat (heart-beat in seconds offered)
- setRequestTimeout(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds)
- setRequestTimeout(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds)
- setRequestTimeoutCheckerInterval(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Set requestTimeoutCheckerInterval for inOut exchange
- setRequestTimeoutCheckerInterval(long) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Set requestTimeoutCheckerInterval for inOut exchange
- setReQueue(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setRoutingKey(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The routing key to use when binding a consumer queue to the exchange.
- setScheduledExecutorService(ScheduledExecutorService) - Method in interface org.apache.camel.component.rabbitmq.reply.ReplyManager
-
Sets the scheduled to use when checking for timeouts (no reply received within a given time period)
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.component.rabbitmq.reply.ReplyManagerSupport
-
- setScheme(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQSendDynamicAware
-
- setSkipDlqDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If true the producer will not declare and bind a dead letter queue.
- setSkipExchangeDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
This can be used if we need to declare the queue but not the exchange
- setSkipExchangeDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
This can be used if we need to declare the queue but not the exchange
- setSkipQueueBind(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
- setSkipQueueBind(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
- setSkipQueueDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
If true the producer will not declare and bind a queue.
- setSkipQueueDeclare(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
If true the producer will not declare and bind a queue.
- setSslProtocol(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Enables SSL on connection, accepted value are `true`, `TLS` and 'SSLv3`
- setSslProtocol(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Enables SSL on connection, accepted value are `true`, `TLS` and 'SSLv3`
- setThreadPoolSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The consumer uses a Thread Pool Executor with a fixed number of threads.
- setThreadPoolSize(int) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The consumer uses a Thread Pool Executor with a fixed number of threads.
- setTopologyRecoveryEnabled(Boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Enables connection topology recovery (should topology recovery be performed?)
- setTopologyRecoveryEnabled(Boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Enables connection topology recovery (should topology recovery be performed?)
- setTransferException(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response
- setTransferException(boolean) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response
- setTrustManager(TrustManager) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Configure SSL trust manager, SSL should be enabled for this option to be effective
- setTrustManager(TrustManager) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Configure SSL trust manager, SSL should be enabled for this option to be effective
- setUsername(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
Username in case of authenticated access
- setUsername(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
Username in case of authenticated access
- setVhost(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQComponent
-
The vhost for the channel
- setVhost(String) - Method in class org.apache.camel.component.rabbitmq.RabbitMQEndpoint
-
The vhost for the channel