@Component(value="rabbitmq")
public class RabbitMQComponent
extends org.apache.camel.support.DefaultComponent
Modifier and Type | Field and Description |
---|---|
static String |
ARG_PREFIX |
static String |
BINDING_ARG_PREFIX |
static String |
DLQ_ARG_PREFIX |
static String |
DLQ_BINDING_PREFIX |
static String |
EXCHANGE_ARG_PREFIX |
static String |
QUEUE_ARG_PREFIX |
Constructor and Description |
---|
RabbitMQComponent() |
RabbitMQComponent(org.apache.camel.CamelContext context) |
Modifier and Type | Method and Description |
---|---|
protected RabbitMQEndpoint |
createEndpoint(String uri,
String remaining,
Map<String,Object> params) |
Map<String,Object> |
getAdditionalHeaders() |
Map<String,Object> |
getAdditionalProperties() |
String |
getAddresses() |
Map<String,Object> |
getArgs() |
Boolean |
getAutomaticRecoveryEnabled() |
int |
getChannelPoolMaxSize()
Get maximum number of opened channel in pool
|
long |
getChannelPoolMaxWait() |
Map<String,Object> |
getClientProperties() |
com.rabbitmq.client.ConnectionFactory |
getConnectionFactory() |
com.rabbitmq.client.ExceptionHandler |
getConnectionFactoryExceptionHandler() |
int |
getConnectionTimeout() |
String |
getDeadLetterExchange() |
String |
getDeadLetterExchangeType() |
String |
getDeadLetterQueue() |
String |
getDeadLetterRoutingKey() |
String |
getHostname() |
Integer |
getNetworkRecoveryInterval() |
String |
getPassword() |
int |
getPortNumber() |
int |
getPrefetchCount() |
int |
getPrefetchSize() |
long |
getPublisherAcknowledgementsTimeout()
The amount of time in milliseconds to wait for a basic.ack response from RabbitMQ server
|
int |
getRequestedChannelMax() |
int |
getRequestedFrameMax() |
int |
getRequestedHeartbeat() |
long |
getRequestTimeout() |
long |
getRequestTimeoutCheckerInterval() |
String |
getSslProtocol() |
int |
getThreadPoolSize() |
Boolean |
getTopologyRecoveryEnabled() |
TrustManager |
getTrustManager() |
String |
getUsername() |
String |
getVhost() |
boolean |
isAllowNullHeaders()
Allow pass null values to header
|
boolean |
isAutoAck() |
boolean |
isAutoDelete() |
boolean |
isAutoDetectConnectionFactory() |
boolean |
isDeclare() |
boolean |
isDurable() |
boolean |
isExclusive() |
boolean |
isExclusiveConsumer() |
boolean |
isGuaranteedDeliveries()
When true, an exception will be thrown when the message cannot be delivered (basic.return) and the message is
marked as mandatory.
|
boolean |
isImmediate() |
boolean |
isMandatory() |
boolean |
isPassive() |
boolean |
isPrefetchEnabled() |
boolean |
isPrefetchGlobal() |
boolean |
isPublisherAcknowledgements()
When true, the message will be published with publisher
acknowledgements turned on
|
boolean |
isRecoverFromDeclareException() |
boolean |
isSkipExchangeDeclare() |
boolean |
isSkipQueueBind()
If true the queue will not be bound to the exchange after declaring it
|
boolean |
isSkipQueueDeclare() |
boolean |
isTransferException() |
void |
setAdditionalHeaders(Map<String,Object> additionalHeaders)
Map of additional headers.
|
void |
setAdditionalProperties(Map<String,Object> additionalProperties)
Map of additional properties.
|
void |
setAddresses(String addresses)
If this option is set, camel-rabbitmq will try to create connection based on the setting of option addresses.
|
void |
setAllowNullHeaders(boolean allowNullHeaders) |
void |
setArgs(Map<String,Object> 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/queue?args=arg.queue.x-message-ttl=60000
|
void |
setAutoAck(boolean autoAck)
If messages should be auto acknowledged
|
void |
setAutoDelete(boolean autoDelete)
If it is true, the exchange will be deleted when it is no longer in use
|
void |
setAutoDetectConnectionFactory(boolean autoDetectConnectionFactory)
Whether to auto-detect looking up RabbitMQ connection factory from the registry.
|
void |
setAutomaticRecoveryEnabled(Boolean automaticRecoveryEnabled)
Enables connection automatic recovery (uses connection implementation that performs automatic recovery when
connection shutdown is not initiated by the application)
|
void |
setChannelPoolMaxSize(int channelPoolMaxSize) |
void |
setChannelPoolMaxWait(long channelPoolMaxWait)
Set the maximum number of milliseconds to wait for a channel from the pool
|
void |
setClientProperties(Map<String,Object> clientProperties)
Connection client properties (client info used in negotiating with the server)
|
void |
setConnectionFactory(com.rabbitmq.client.ConnectionFactory connectionFactory)
To use a custom RabbitMQ connection factory.
|
void |
setConnectionFactoryExceptionHandler(com.rabbitmq.client.ExceptionHandler connectionFactoryExceptionHandler)
Custom rabbitmq ExceptionHandler for ConnectionFactory
|
void |
setConnectionTimeout(int connectionTimeout)
Connection timeout
|
void |
setDeadLetterExchange(String deadLetterExchange)
The name of the dead letter exchange
|
void |
setDeadLetterExchangeType(String deadLetterExchangeType)
The type of the dead letter exchange
|
void |
setDeadLetterQueue(String deadLetterQueue)
The name of the dead letter queue
|
void |
setDeadLetterRoutingKey(String deadLetterRoutingKey)
The routing key for the dead letter exchange
|
void |
setDeclare(boolean declare)
If the option is true, camel declare the exchange and queue name and bind them together.
|
void |
setDurable(boolean durable)
If we are declaring a durable exchange (the exchange will survive a server restart)
|
void |
setExclusive(boolean exclusive)
Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes.
|
void |
setExclusiveConsumer(boolean exclusiveConsumer)
Request exclusive access to the queue (meaning only this consumer can access the queue).
|
void |
setGuaranteedDeliveries(boolean guaranteedDeliveries) |
void |
setHostname(String hostname)
The hostname of the running RabbitMQ instance or cluster.
|
void |
setImmediate(boolean immediate)
This flag tells the server how to react if the message cannot be routed to a queue consumer immediately.
|
void |
setMandatory(boolean mandatory)
This flag tells the server how to react if the message cannot be routed to a queue.
|
void |
setNetworkRecoveryInterval(Integer networkRecoveryInterval)
Network recovery interval in milliseconds (interval used when recovering from network failure)
|
void |
setPassive(boolean passive)
Passive queues depend on the queue already to be available at RabbitMQ.
|
void |
setPassword(String password)
Password for authenticated access
|
void |
setPortNumber(int portNumber)
Port number for the host with the running rabbitmq instance or cluster.
|
void |
setPrefetchCount(int prefetchCount)
The maximum number of messages that the server will deliver, 0 if unlimited.
|
void |
setPrefetchEnabled(boolean prefetchEnabled)
Enables the quality of service on the RabbitMQConsumer side.
|
void |
setPrefetchGlobal(boolean prefetchGlobal)
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
|
void |
setPrefetchSize(int prefetchSize)
The maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited.
|
void |
setPublisherAcknowledgements(boolean publisherAcknowledgements) |
void |
setPublisherAcknowledgementsTimeout(long publisherAcknowledgementsTimeout) |
void |
setRecoverFromDeclareException(boolean recoverFromDeclareException)
Decides whether an exception during declaration of exchanges or queues is recoverable or not.
|
void |
setRequestedChannelMax(int requestedChannelMax)
Connection requested channel max (max number of channels offered)
|
void |
setRequestedFrameMax(int requestedFrameMax)
Connection requested frame max (max size of frame offered)
|
void |
setRequestedHeartbeat(int requestedHeartbeat)
Connection requested heartbeat (heart-beat in seconds offered)
|
void |
setRequestTimeout(long requestTimeout)
Set timeout for waiting for a reply when using the InOut Exchange Pattern (in milliseconds)
|
void |
setRequestTimeoutCheckerInterval(long requestTimeoutCheckerInterval)
Set requestTimeoutCheckerInterval for inOut exchange
|
void |
setSkipExchangeDeclare(boolean skipExchangeDeclare)
This can be used if we need to declare the queue but not the exchange
|
void |
setSkipQueueBind(boolean skipQueueBind) |
void |
setSkipQueueDeclare(boolean skipQueueDeclare)
If true the producer will not declare and bind a queue.
|
void |
setSslProtocol(String sslProtocol)
Enables SSL on connection, accepted value are `true`, `TLS` and 'SSLv3`
|
void |
setThreadPoolSize(int threadPoolSize)
The consumer uses a Thread Pool Executor with a fixed number of threads.
|
void |
setTopologyRecoveryEnabled(Boolean topologyRecoveryEnabled)
Enables connection topology recovery (should topology recovery be performed?)
|
void |
setTransferException(boolean transferException)
When true and an inOut Exchange failed on the consumer side send the caused Exception back in the response
|
void |
setTrustManager(TrustManager trustManager)
Configure SSL trust manager, SSL should be enabled for this option to be effective
|
void |
setUsername(String username)
Username in case of authenticated access
|
void |
setVhost(String vhost)
The vhost for the channel
|
afterConfiguration, createEndpoint, createEndpoint, doBuild, doInit, doStart, doStop, getAndRemoveOrResolveReferenceParameter, getAndRemoveOrResolveReferenceParameter, getAndRemoveParameter, getAndRemoveParameter, getCamelContext, getComponentPropertyConfigurer, getDefaultName, getEndpointPropertyConfigurer, getExtension, getSupportedExtensions, ifStartsWithReturnRemainder, isAutowiredEnabled, isBridgeErrorHandler, isLazyStartProducer, registerExtension, registerExtension, resolveAndRemoveReferenceListParameter, resolveAndRemoveReferenceListParameter, resolveAndRemoveReferenceParameter, resolveAndRemoveReferenceParameter, resolveRawParameterValues, setAutowiredEnabled, setBridgeErrorHandler, setCamelContext, setLazyStartProducer, setProperties, setProperties, setProperties, useIntrospectionOnEndpoint, useRawUri, validateParameters, validateURI
build, doFail, doLifecycleChange, doResume, doShutdown, doSuspend, fail, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
public static final String ARG_PREFIX
public static final String EXCHANGE_ARG_PREFIX
public static final String QUEUE_ARG_PREFIX
public static final String DLQ_ARG_PREFIX
public static final String DLQ_BINDING_PREFIX
public static final String BINDING_ARG_PREFIX
public RabbitMQComponent()
public RabbitMQComponent(org.apache.camel.CamelContext context)
protected RabbitMQEndpoint createEndpoint(String uri, String remaining, Map<String,Object> params) throws Exception
createEndpoint
in class org.apache.camel.support.DefaultComponent
Exception
public String getHostname()
public void setHostname(String hostname)
public int getPortNumber()
public void setPortNumber(int portNumber)
public String getUsername()
public void setUsername(String username)
public String getPassword()
public void setPassword(String password)
public String getVhost()
public void setVhost(String vhost)
public void setAddresses(String addresses)
public String getAddresses()
public com.rabbitmq.client.ConnectionFactory getConnectionFactory()
public void setConnectionFactory(com.rabbitmq.client.ConnectionFactory connectionFactory)
public int getThreadPoolSize()
public void setThreadPoolSize(int threadPoolSize)
public boolean isAutoDetectConnectionFactory()
public void setAutoDetectConnectionFactory(boolean autoDetectConnectionFactory)
public int getConnectionTimeout()
public void setConnectionTimeout(int connectionTimeout)
public int getRequestedChannelMax()
public void setRequestedChannelMax(int requestedChannelMax)
public int getRequestedFrameMax()
public void setRequestedFrameMax(int requestedFrameMax)
public int getRequestedHeartbeat()
public void setRequestedHeartbeat(int requestedHeartbeat)
public Boolean getAutomaticRecoveryEnabled()
public void setAutomaticRecoveryEnabled(Boolean automaticRecoveryEnabled)
public Integer getNetworkRecoveryInterval()
public void setNetworkRecoveryInterval(Integer networkRecoveryInterval)
public Boolean getTopologyRecoveryEnabled()
public void setTopologyRecoveryEnabled(Boolean topologyRecoveryEnabled)
public boolean isPrefetchEnabled()
public void setPrefetchEnabled(boolean prefetchEnabled)
public void setPrefetchSize(int prefetchSize)
public int getPrefetchSize()
public void setPrefetchCount(int prefetchCount)
public int getPrefetchCount()
public void setPrefetchGlobal(boolean prefetchGlobal)
public boolean isPrefetchGlobal()
public int getChannelPoolMaxSize()
public void setChannelPoolMaxSize(int channelPoolMaxSize)
public long getChannelPoolMaxWait()
public void setChannelPoolMaxWait(long channelPoolMaxWait)
public void setRequestTimeout(long requestTimeout)
public long getRequestTimeout()
public void setRequestTimeoutCheckerInterval(long requestTimeoutCheckerInterval)
public long getRequestTimeoutCheckerInterval()
public void setTransferException(boolean transferException)
public boolean isTransferException()
public boolean isPublisherAcknowledgements()
public void setPublisherAcknowledgements(boolean publisherAcknowledgements)
public long getPublisherAcknowledgementsTimeout()
public void setPublisherAcknowledgementsTimeout(long publisherAcknowledgementsTimeout)
public boolean isGuaranteedDeliveries()
public void setGuaranteedDeliveries(boolean guaranteedDeliveries)
public boolean isMandatory()
public void setMandatory(boolean mandatory)
public boolean isImmediate()
public void setImmediate(boolean immediate)
public void setArgs(Map<String,Object> args)
public void setClientProperties(Map<String,Object> clientProperties)
public String getSslProtocol()
public void setSslProtocol(String sslProtocol)
public TrustManager getTrustManager()
public void setTrustManager(TrustManager trustManager)
public boolean isAutoAck()
public void setAutoAck(boolean autoAck)
public boolean isAutoDelete()
public void setAutoDelete(boolean autoDelete)
public boolean isDurable()
public void setDurable(boolean durable)
public boolean isExclusive()
public void setExclusive(boolean exclusive)
public boolean isExclusiveConsumer()
public void setExclusiveConsumer(boolean exclusiveConsumer)
public boolean isPassive()
public void setPassive(boolean passive)
public void setSkipQueueDeclare(boolean skipQueueDeclare)
public boolean isSkipQueueDeclare()
public boolean isSkipQueueBind()
public void setSkipQueueBind(boolean skipQueueBind)
public void setSkipExchangeDeclare(boolean skipExchangeDeclare)
public boolean isSkipExchangeDeclare()
public boolean isDeclare()
public void setDeclare(boolean declare)
public String getDeadLetterExchange()
public void setDeadLetterExchange(String deadLetterExchange)
public String getDeadLetterQueue()
public void setDeadLetterQueue(String deadLetterQueue)
public String getDeadLetterRoutingKey()
public void setDeadLetterRoutingKey(String deadLetterRoutingKey)
public String getDeadLetterExchangeType()
public void setDeadLetterExchangeType(String deadLetterExchangeType)
public boolean isAllowNullHeaders()
public void setAllowNullHeaders(boolean allowNullHeaders)
public void setAdditionalHeaders(Map<String,Object> additionalHeaders)
public void setAdditionalProperties(Map<String,Object> additionalProperties)
AMQP.BasicProperties
The map keys should be from
RabbitMQConstants
. Any other keys will be ignored. When the message
already contains these headers they will be given precedence over these properties.public com.rabbitmq.client.ExceptionHandler getConnectionFactoryExceptionHandler()
public void setConnectionFactoryExceptionHandler(com.rabbitmq.client.ExceptionHandler connectionFactoryExceptionHandler)
public boolean isRecoverFromDeclareException()
public void setRecoverFromDeclareException(boolean recoverFromDeclareException)
Apache Camel