org.apache.camel.component.rabbitmq
Class RabbitMQEndpoint

java.lang.Object
  extended by org.apache.camel.support.ServiceSupport
      extended by org.apache.camel.impl.DefaultEndpoint
          extended by org.apache.camel.component.rabbitmq.RabbitMQEndpoint
All Implemented Interfaces:
org.apache.camel.CamelContextAware, org.apache.camel.Endpoint, org.apache.camel.IsSingleton, org.apache.camel.Service, org.apache.camel.ShutdownableService, org.apache.camel.spi.HasId, org.apache.camel.StatefulService, org.apache.camel.SuspendableService

public class RabbitMQEndpoint
extends org.apache.camel.impl.DefaultEndpoint


Field Summary
 
Fields inherited from class org.apache.camel.support.ServiceSupport
shutdown, shuttingdown, started, starting, stopped, stopping, suspended, suspending
 
Constructor Summary
RabbitMQEndpoint()
           
RabbitMQEndpoint(String endpointUri, RabbitMQComponent component)
           
 
Method Summary
 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)
           
 com.rabbitmq.client.Address[] getAddresses()
           
 String getExchangeName()
           
 String getExchangeType()
           
 String getHostname()
           
 String getPassword()
           
 int getPortNumber()
           
 String getQueue()
           
 String getRoutingKey()
           
 int getThreadPoolSize()
           
 String getUsername()
           
 String getVhost()
           
 boolean isAutoAck()
           
 boolean isAutoDelete()
           
 boolean isBridgeEndpoint()
           
 boolean isDurable()
           
 boolean isSingleton()
           
 void setAddresses(String addresses)
           
 void setAutoAck(boolean autoAck)
           
 void setAutoDelete(boolean autoDelete)
           
 void setBridgeEndpoint(boolean bridgeEndpoint)
           
 void setDurable(boolean durable)
           
 void setExchangeName(String exchangeName)
           
 void setExchangeType(String exchangeType)
           
 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)
           
 
Methods inherited from class org.apache.camel.impl.DefaultEndpoint
configureConsumer, configurePollingConsumer, 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, setProperties, setSynchronous, toString
 
Methods inherited from class org.apache.camel.support.ServiceSupport
doResume, doShutdown, doSuspend, getStatus, getVersion, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, resume, shutdown, start, stop, suspend
 
Methods inherited from class java.lang.Object
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
 
Methods inherited from interface org.apache.camel.Service
start, stop
 

Constructor Detail

RabbitMQEndpoint

public RabbitMQEndpoint()

RabbitMQEndpoint

public RabbitMQEndpoint(String endpointUri,
                        RabbitMQComponent component)
                 throws URISyntaxException
Throws:
URISyntaxException
Method Detail

createRabbitExchange

public org.apache.camel.Exchange createRabbitExchange(com.rabbitmq.client.Envelope envelope,
                                                      com.rabbitmq.client.AMQP.BasicProperties properties,
                                                      byte[] body)

createConsumer

public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor)
                                         throws Exception
Throws:
Exception

connect

public com.rabbitmq.client.Connection connect(ExecutorService executor)
                                       throws IOException
Throws:
IOException

createProducer

public org.apache.camel.Producer createProducer()
                                         throws Exception
Throws:
Exception

isSingleton

public boolean isSingleton()

createExecutor

protected ExecutorService createExecutor()

getUsername

public String getUsername()

setUsername

public void setUsername(String username)

getPassword

public String getPassword()

setPassword

public void setPassword(String password)

getVhost

public String getVhost()

setVhost

public void setVhost(String vhost)

getHostname

public String getHostname()

setHostname

public void setHostname(String hostname)

getThreadPoolSize

public int getThreadPoolSize()

setThreadPoolSize

public void setThreadPoolSize(int threadPoolSize)

getPortNumber

public int getPortNumber()

setPortNumber

public void setPortNumber(int portNumber)

isAutoAck

public boolean isAutoAck()

setAutoAck

public void setAutoAck(boolean autoAck)

isAutoDelete

public boolean isAutoDelete()

setAutoDelete

public void setAutoDelete(boolean autoDelete)

isDurable

public boolean isDurable()

setDurable

public void setDurable(boolean durable)

getQueue

public String getQueue()

setQueue

public void setQueue(String queue)

getExchangeName

public String getExchangeName()

setExchangeName

public void setExchangeName(String exchangeName)

getExchangeType

public String getExchangeType()

setExchangeType

public void setExchangeType(String exchangeType)

getRoutingKey

public String getRoutingKey()

setRoutingKey

public void setRoutingKey(String routingKey)

setBridgeEndpoint

public void setBridgeEndpoint(boolean bridgeEndpoint)

isBridgeEndpoint

public boolean isBridgeEndpoint()

setAddresses

public void setAddresses(String addresses)

getAddresses

public com.rabbitmq.client.Address[] getAddresses()


Apache Camel