public class RabbitMQConsumer
extends org.apache.camel.support.DefaultConsumer
implements org.apache.camel.Suspendable
Constructor and Description |
---|
RabbitMQConsumer(RabbitMQEndpoint endpoint,
org.apache.camel.Processor processor) |
Modifier and Type | Method and Description |
---|---|
org.apache.camel.Exchange |
createExchange(com.rabbitmq.client.Envelope envelope,
com.rabbitmq.client.AMQP.BasicProperties properties,
byte[] body) |
protected void |
doResume() |
protected void |
doStart() |
protected void |
doStop() |
protected void |
doSuspend() |
protected com.rabbitmq.client.Connection |
getConnection()
Returns the exiting open connection or opens a new one
|
RabbitMQEndpoint |
getEndpoint() |
createExchange, createUoW, defaultConsumerCallback, doBuild, doInit, doneUoW, doShutdown, getAsyncProcessor, getExceptionHandler, getHealthCheck, getProcessor, getRoute, getRouteId, handleException, handleException, releaseExchange, setExceptionHandler, setHealthCheck, setRoute, setRouteId, toString
build, doFail, doLifecycleChange, 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, wait, wait, wait
public RabbitMQConsumer(RabbitMQEndpoint endpoint, org.apache.camel.Processor processor)
public RabbitMQEndpoint getEndpoint()
getEndpoint
in interface org.apache.camel.EndpointAware
getEndpoint
in class org.apache.camel.support.DefaultConsumer
protected com.rabbitmq.client.Connection getConnection() throws IOException, TimeoutException
IOException
TimeoutException
public org.apache.camel.Exchange createExchange(com.rabbitmq.client.Envelope envelope, com.rabbitmq.client.AMQP.BasicProperties properties, byte[] body)
protected void doSuspend() throws Exception
doSuspend
in class org.apache.camel.support.service.BaseService
Exception
protected void doResume() throws Exception
doResume
in class org.apache.camel.support.service.BaseService
Exception
protected void doStart() throws Exception
doStart
in class org.apache.camel.support.DefaultConsumer
Exception
Apache Camel