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 |
|---|---|
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, doInit, doneUoW, getAsyncProcessor, getExceptionHandler, getProcessor, getRoute, handleException, handleException, setExceptionHandler, setRoute, toStringbuild, doBuild, doShutdown, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspendpublic RabbitMQConsumer(RabbitMQEndpoint endpoint, org.apache.camel.Processor processor)
public RabbitMQEndpoint getEndpoint()
getEndpoint in interface org.apache.camel.EndpointAwaregetEndpoint in class org.apache.camel.support.DefaultConsumerprotected com.rabbitmq.client.Connection getConnection()
throws IOException,
TimeoutException
IOExceptionTimeoutExceptionprotected void doSuspend()
throws Exception
doSuspend in class org.apache.camel.support.service.ServiceSupportExceptionprotected void doResume()
throws Exception
doResume in class org.apache.camel.support.service.ServiceSupportExceptionprotected void doStart()
throws Exception
doStart in class org.apache.camel.support.DefaultConsumerExceptionApache Camel