public class RabbitMQEndpoint
extends org.apache.camel.impl.DefaultEndpoint
Constructor and Description |
---|
RabbitMQEndpoint() |
RabbitMQEndpoint(String endpointUri,
RabbitMQComponent component) |
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,
byte[] body) |
String |
getExchangeName() |
String |
getHostname() |
String |
getPassword() |
int |
getPortNumber() |
String |
getQueue() |
String |
getRoutingKey() |
int |
getThreadPoolSize() |
String |
getUsername() |
String |
getVhost() |
boolean |
isAutoAck() |
boolean |
isAutoDelete() |
boolean |
isDurable() |
boolean |
isSingleton() |
void |
setAutoAck(boolean autoAck) |
void |
setAutoDelete(boolean autoDelete) |
void |
setDurable(boolean durable) |
void |
setExchangeName(String exchangeName) |
void |
setHostname(String hostname) |
void |
setPassword(String password) |
void |
setPortNumber(int portNumber) |
void |
setQueue(String queue) |
void |
setRoutingKey(String routingKey) |
void |
setThreadPoolSize(int threadPoolSize) |
void |
setUsername(String username) |
void |
setVhost(String vhost) |
configureConsumer, configureProperties, createEndpointConfiguration, createEndpointUri, createExchange, createExchange, createExchange, createPollingConsumer, doStart, doStop, equals, getCamelContext, getComponent, getConsumerProperties, getEndpointConfiguration, getEndpointKey, getEndpointUri, getExchangePattern, getId, hashCode, isLenientProperties, isSynchronous, setCamelContext, setConsumerProperties, setEndpointConfiguration, setEndpointUri, setEndpointUriIfNotSpecified, setExchangePattern, 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 org.apache.camel.Exchange createRabbitExchange(com.rabbitmq.client.Envelope envelope, 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 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 getRoutingKey()
public void setRoutingKey(String routingKey)
Apache Camel