public class RabbitMQEndpoint
extends org.apache.camel.impl.DefaultEndpoint
Constructor and Description |
---|
RabbitMQEndpoint() |
RabbitMQEndpoint(String endpointUri,
RabbitMQComponent component) |
RabbitMQEndpoint(String endpointUri,
RabbitMQComponent component,
com.rabbitmq.client.ConnectionFactory connectionFactory) |
Modifier and Type | Method and Description |
---|---|
com.rabbitmq.client.Connection |
connect(ExecutorService executor) |
org.apache.camel.Consumer |
createConsumer(org.apache.camel.Processor processor) |
protected ExecutorService |
createExecutor() |
org.apache.camel.Producer |
createProducer() |
org.apache.camel.Exchange |
createRabbitExchange(com.rabbitmq.client.Envelope envelope,
com.rabbitmq.client.AMQP.BasicProperties properties,
byte[] body) |
void |
declareExchangeAndQueue(com.rabbitmq.client.Channel channel)
If needed, declare Exchange, declare Queue and bind them with Routing Key
|
com.rabbitmq.client.Address[] |
getAddresses() |
Boolean |
getAutomaticRecoveryEnabled() |
Map<String,Object> |
getClientProperties() |
int |
getConcurrentConsumers() |
com.rabbitmq.client.ConnectionFactory |
getConnectionFactory() |
int |
getConnectionTimeout() |
String |
getDeadLetterExchange() |
String |
getDeadLetterExchangeType() |
String |
getDeadLetterQueue() |
String |
getDeadLetterRoutingKey() |
String |
getExchangeName() |
String |
getExchangeType() |
String |
getHostname() |
Integer |
getNetworkRecoveryInterval() |
String |
getPassword() |
int |
getPortNumber() |
int |
getPrefetchCount() |
int |
getPrefetchSize() |
String |
getQueue() |
int |
getRequestedChannelMax() |
int |
getRequestedFrameMax() |
int |
getRequestedHeartbeat() |
String |
getRoutingKey() |
String |
getSslProtocol() |
int |
getThreadPoolSize() |
Boolean |
getTopologyRecoveryEnabled() |
TrustManager |
getTrustManager() |
String |
getUsername() |
String |
getVhost() |
boolean |
isAutoAck() |
boolean |
isAutoDelete() |
boolean |
isBridgeEndpoint() |
boolean |
isDeclare() |
boolean |
isDurable() |
boolean |
isPrefetchEnabled() |
boolean |
isPrefetchGlobal() |
boolean |
isSingleton() |
void |
setAddresses(String addresses) |
void |
setAutoAck(boolean autoAck) |
void |
setAutoDelete(boolean autoDelete) |
void |
setAutomaticRecoveryEnabled(Boolean automaticRecoveryEnabled) |
void |
setBridgeEndpoint(boolean bridgeEndpoint) |
void |
setClientProperties(Map<String,Object> clientProperties) |
void |
setConcurrentConsumers(int concurrentConsumers) |
void |
setConnectionFactory(com.rabbitmq.client.ConnectionFactory connectionFactory) |
void |
setConnectionTimeout(int connectionTimeout) |
void |
setDeadLetterExchange(String deadLetterExchange) |
void |
setDeadLetterExchangeType(String deadLetterExchangeType) |
void |
setDeadLetterQueue(String deadLetterQueue) |
void |
setDeadLetterRoutingKey(String deadLetterRoutingKey) |
void |
setDeclare(boolean declare) |
void |
setDurable(boolean durable) |
void |
setExchangeName(String exchangeName) |
void |
setExchangeType(String exchangeType) |
void |
setHostname(String hostname) |
void |
setNetworkRecoveryInterval(Integer networkRecoveryInterval) |
void |
setPassword(String password) |
void |
setPortNumber(int portNumber) |
void |
setPrefetchCount(int prefetchCount) |
void |
setPrefetchEnabled(boolean prefetchEnabled) |
void |
setPrefetchGlobal(boolean prefetchGlobal) |
void |
setPrefetchSize(int prefetchSize) |
void |
setQueue(String queue) |
void |
setRequestedChannelMax(int requestedChannelMax) |
void |
setRequestedFrameMax(int requestedFrameMax) |
void |
setRequestedHeartbeat(int requestedHeartbeat) |
void |
setRoutingKey(String routingKey) |
void |
setSslProtocol(String sslProtocol) |
void |
setThreadPoolSize(int threadPoolSize) |
void |
setTopologyRecoveryEnabled(Boolean topologyRecoveryEnabled) |
void |
setTrustManager(TrustManager trustManager) |
void |
setUsername(String username) |
void |
setVhost(String vhost) |
configureConsumer, configurePollingConsumer, configureProperties, createEndpointConfiguration, createEndpointUri, createExchange, createExchange, createExchange, createPollingConsumer, doStart, doStop, equals, getCamelContext, getComponent, getConsumerProperties, getEndpointConfiguration, getEndpointKey, getEndpointUri, getExchangePattern, getId, getPollingConsumerQueueSize, hashCode, isLenientProperties, isPollingConsumerBlockWhenFull, isSynchronous, setCamelContext, setConsumerProperties, setEndpointConfiguration, setEndpointUri, setEndpointUriIfNotSpecified, setExchangePattern, setPollingConsumerBlockWhenFull, setPollingConsumerQueueSize, setProperties, setSynchronous, toString
doResume, doShutdown, doSuspend, getStatus, getVersion, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, resume, shutdown, start, stop, suspend
public RabbitMQEndpoint()
public RabbitMQEndpoint(String endpointUri, RabbitMQComponent component) throws URISyntaxException
URISyntaxException
public RabbitMQEndpoint(String endpointUri, RabbitMQComponent component, com.rabbitmq.client.ConnectionFactory connectionFactory) throws URISyntaxException
URISyntaxException
public org.apache.camel.Exchange createRabbitExchange(com.rabbitmq.client.Envelope envelope, com.rabbitmq.client.AMQP.BasicProperties properties, byte[] body)
public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor) throws Exception
Exception
public com.rabbitmq.client.Connection connect(ExecutorService executor) throws IOException
IOException
public void declareExchangeAndQueue(com.rabbitmq.client.Channel channel) throws IOException
IOException
public boolean isSingleton()
protected ExecutorService createExecutor()
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 String getHostname()
public void setHostname(String hostname)
public int getThreadPoolSize()
public void setThreadPoolSize(int threadPoolSize)
public int getPortNumber()
public void setPortNumber(int portNumber)
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 String getQueue()
public void setQueue(String queue)
public String getExchangeName()
public void setExchangeName(String exchangeName)
public String getExchangeType()
public void setExchangeType(String exchangeType)
public String getRoutingKey()
public void setRoutingKey(String routingKey)
public void setBridgeEndpoint(boolean bridgeEndpoint)
public boolean isBridgeEndpoint()
public void setAddresses(String addresses)
public com.rabbitmq.client.Address[] getAddresses()
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 String getSslProtocol()
public void setSslProtocol(String sslProtocol)
public com.rabbitmq.client.ConnectionFactory getConnectionFactory()
public void setConnectionFactory(com.rabbitmq.client.ConnectionFactory connectionFactory)
public TrustManager getTrustManager()
public void setTrustManager(TrustManager trustManager)
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 getConcurrentConsumers()
public void setConcurrentConsumers(int concurrentConsumers)
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)
Apache Camel