public class RabbitMQConsumer
extends org.apache.camel.impl.DefaultConsumer
implements org.apache.camel.Suspendable
Constructor and Description |
---|
RabbitMQConsumer(RabbitMQEndpoint endpoint,
org.apache.camel.Processor processor) |
Modifier and Type | Method and Description |
---|---|
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() |
createUoW, doneUoW, getAsyncProcessor, getExceptionHandler, getProcessor, getRoute, handleException, handleException, setExceptionHandler, setRoute, toString
doShutdown, getStatus, getVersion, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
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.impl.DefaultConsumer
protected com.rabbitmq.client.Connection getConnection() throws IOException, TimeoutException
IOException
TimeoutException
protected void doSuspend() throws Exception
doSuspend
in class org.apache.camel.support.ServiceSupport
Exception
protected void doResume() throws Exception
doResume
in class org.apache.camel.support.ServiceSupport
Exception
protected void doStart() throws Exception
doStart
in class org.apache.camel.impl.DefaultConsumer
Exception
Apache Camel