Skip navigation links
A B C D E F G H I L M N O P Q R S T U V W X 

A

abort() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
abort(int, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
AbstractAdaptableMessageListener - Class in org.springframework.amqp.rabbit.listener.adapter
An abstract MessageListener adapter providing the necessary infrastructure to extract the payload of a Message
AbstractAdaptableMessageListener() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
AbstractAdaptableMessageListener.ReplyExpressionRoot - Class in org.springframework.amqp.rabbit.listener.adapter
 
AbstractAdaptableMessageListener.ResultHolder - Class in org.springframework.amqp.rabbit.listener.adapter
 
AbstractConnectionFactory - Class in org.springframework.amqp.rabbit.connection
 
AbstractConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Create a new AbstractConnectionFactory for the given target ConnectionFactory.
AbstractExchangeParser - Class in org.springframework.amqp.rabbit.config
 
AbstractExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
AbstractMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
 
AbstractMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
AbstractMessageListenerContainer.SharedConnectionNotInitializedException - Exception in org.springframework.amqp.rabbit.listener
Exception that indicates that the initial setup of this container's shared Rabbit Connection failed.
AbstractRabbitListenerContainerFactory<C extends AbstractMessageListenerContainer> - Class in org.springframework.amqp.rabbit.config
Base RabbitListenerContainerFactory for Spring's base container implementation.
AbstractRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
AbstractRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.listener
Base model for a Rabbit listener endpoint
AbstractRabbitListenerEndpoint() - Constructor for class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
AbstractRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
Convenient base class for interceptor factories.
AbstractRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
AbstractRoutingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
Abstract ConnectionFactory implementation that routes AbstractRoutingConnectionFactory.createConnection() calls to one of various target ConnectionFactories based on a lookup key.
AbstractRoutingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
activateOptions() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
ActiveObjectCounter<T> - Class in org.springframework.amqp.rabbit.listener
 
ActiveObjectCounter() - Constructor for class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 
add(T) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 
addAndStartConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
addChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
addChannel(Channel, Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
addChannelListener(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
addConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
addConnection(Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
addConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
addConstructorArgBooleanValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition constructor argument with the boolean value of that attribute if it is defined in the given element or else uses the default provided.
addConstructorArgParentRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition constructor argument with a reference to a bean with parent id equal to the attribute if it is defined in the given element.
addConstructorArgRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition constructor argument with a reference to a bean with id equal to the attribute if it is defined in the given element.
addConstructorArgValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition constructor argument with the value of that attribute if it is defined in the given element.
addDelegate(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
addDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
addDeliveryTag(Channel, long) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
addExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
addExchange(String, Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
addFlowListener(FlowListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
additionalHeaders(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
Subclasses can override this method to add more headers to the republished message.
addListener(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
addListener(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
Add the listener and return the internal map of pending confirmations for that listener.
addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
Adds a pending confirmation to this channel's map.
addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
addQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
addQueue(String, Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Add queue(s) to this container's list of queues.
addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Add queue(s) to this container's list of queues.
addQueueOrTagToMethodName(String, String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Add the mapping of a queue name or consumer tag to a method name.
addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Add queue(s) to this container's list of queues.
addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Add queue(s) to this container's list of queues.
addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
addShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
addTargetConnectionFactory(Object, ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Adds the given ConnectionFactory and associates it with the given lookup key
addToBatch(String, String, Message) - Method in interface org.springframework.amqp.rabbit.core.support.BatchingStrategy
Add a message to the batch and optionally release the batch.
addToBatch(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
If autoStartup is set to true, registers a callback on the ConnectionFactory to declare all exchanges and queues in the enclosing application context.
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
Make sure the ConnectionFactory has been set.
afterSingletonsInstantiated() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
AmqpAppender - Class in org.springframework.amqp.rabbit.log4j
Deprecated.
in favor of Apache Log4j 2 (following Apache's EOL declaration for log4j 1.x)
AmqpAppender() - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
AmqpAppender - Class in org.springframework.amqp.rabbit.log4j2
A Log4j 2 appender that publishes logging events to an AMQP Exchange.
AmqpAppender(String, Filter, Layout<? extends Serializable>, boolean, AmqpAppender.AmqpManager) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
AmqpAppender - Class in org.springframework.amqp.rabbit.logback
A Lockback appender that publishes logging events to an AMQP Exchange.
AmqpAppender() - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender
 
AmqpAppender.AmqpManager - Class in org.springframework.amqp.rabbit.log4j2
 
AmqpAppender.Event - Class in org.springframework.amqp.rabbit.log4j
Deprecated.
Small helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
AmqpAppender.Event - Class in org.springframework.amqp.rabbit.log4j2
Helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
AmqpAppender.Event - Class in org.springframework.amqp.rabbit.logback
Small helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.log4j
Deprecated.
Helper class to actually send LoggingEvents asynchronously.
AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.log4j2
Helper class to actually send LoggingEvents asynchronously.
AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.logback
Helper class to actually send LoggingEvents asynchronously.
AmqpManager(LoggerContext, String) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
 
append(LoggingEvent) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
append(LogEvent) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
append(ILoggingEvent) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Key name for the application id (if there is one set via the appender config) in the message properties.
APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Key name for the application id (if there is one set via the appender config) in the message properties.
APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
Key name for the application id (if there is one set via the appender config) in the message properties.
applyCommonSettings(AbstractRetryOperationsInterceptorFactoryBean) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
 
Argument - Annotation Type in org.springframework.amqp.rabbit.annotation
Represents an argument used when declaring queues etc within a QueueBinding.
AsyncConsumerRestartedEvent - Class in org.springframework.amqp.rabbit.listener
An event that is published whenever a consumer is restarted.
AsyncConsumerRestartedEvent(Object, Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
AsyncConsumerStartedEvent - Class in org.springframework.amqp.rabbit.listener
An event that is published whenever a new consumer is started.
AsyncConsumerStartedEvent(Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
 
AsyncConsumerStoppedEvent - Class in org.springframework.amqp.rabbit.listener
An event that is published whenever a consumer is stopped (and not restarted).
AsyncConsumerStoppedEvent(Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
 
AsyncRabbitTemplate - Class in org.springframework.amqp.rabbit
Provides asynchronous send and receive operations returning a ListenableFuture allowing the caller to obtain the reply later, using get() or a callback.
AsyncRabbitTemplate(ConnectionFactory, String, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(ConnectionFactory, String, String, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(RabbitTemplate, SimpleMessageListenerContainer) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(RabbitTemplate, SimpleMessageListenerContainer, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate.RabbitConverterFuture<C> - Class in org.springframework.amqp.rabbit
A AsyncRabbitTemplate.RabbitFuture with a return type of the template's generic parameter.
AsyncRabbitTemplate.RabbitFuture<T> - Class in org.springframework.amqp.rabbit
Base class for ListenableFutures returned by AsyncRabbitTemplate.
AsyncRabbitTemplate.RabbitMessageFuture - Class in org.springframework.amqp.rabbit
A AsyncRabbitTemplate.RabbitFuture with a return type of Message.
asyncRpc(Method) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
AutoRecoverConnectionNotCurrentlyOpenException - Exception in org.springframework.amqp.rabbit.connection
An exception thrown if the connection is an auto recover connection that is not currently open and is in the process of being recovered.
await(Long, TimeUnit) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 

B

backOffOptions(long, double, long) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the backoff options.
backOffOptions(long, double, long) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
backOffPolicy(BackOffPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the back off policy.
backOffPolicy(BackOffPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
BASE_PACKAGE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
basicAck(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicCancel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicCancel(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicCancel(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, String, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, Map<String, Object>, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
Added to the 3.3.x client
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicGet(String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicNack(long, boolean, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicQos(int, int, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicQos(int, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
Added to the 3.3.x client
basicQos(int) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicRecover() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicRecover(boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicReject(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
BatchingRabbitTemplate - Class in org.springframework.amqp.rabbit.core
A RabbitTemplate that permits batching individual messages into a larger message.
BatchingRabbitTemplate(BatchingStrategy, TaskScheduler) - Constructor for class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
BatchingStrategy - Interface in org.springframework.amqp.rabbit.core.support
Strategy for batching messages.
bind(Object, Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Bind the given resource for the given key to the current thread.
BINDING_ARGUMENTS - Static variable in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
BINDING_EXCHANGE_ATTR - Static variable in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
BINDING_QUEUE_ATTR - Static variable in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
BindingFactoryBean - Class in org.springframework.amqp.rabbit.config
 
BindingFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
bindResourceToTransaction(RabbitResourceHolder, ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
 
BlockingQueueConsumer - Class in org.springframework.amqp.rabbit.listener
Specialized consumer encapsulating knowledge of the broker connections and having its own lifecycle (start and stop).
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, boolean, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, boolean, Map<String, Object>, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, boolean, Map<String, Object>, boolean, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
build() - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
 
build() - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
build() - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatelessRetryInterceptorBuilder
 
buildListenerArguments(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Build an array of arguments to be passed into the target listener method.
buildMessage(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Build a Rabbit message to be sent as response based on the given result object.
buildMessage(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
Build a Rabbit message to be sent as response based on the given result object.

C

CachingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
A ConnectionFactory implementation that (when the cache mode is CachingConnectionFactory.CacheMode.CHANNEL (default) returns the same Connection from all CachingConnectionFactory.createConnection() calls, and ignores calls to Connection.close() and caches Channel.
CachingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory initializing the hostname to be the value returned from InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
CachingConnectionFactory(String, int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a host name and port.
CachingConnectionFactory(URI) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a URI.
CachingConnectionFactory(int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a port on the hostname returned from InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
CachingConnectionFactory(String) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a host name.
CachingConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory for the given target ConnectionFactory.
CachingConnectionFactory.CacheMode - Enum in org.springframework.amqp.rabbit.connection
 
cancel(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
 
cancelled() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Key name for the logger level name in the message properties
CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Key name for the logger level name in the message properties
CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
Key name for the logger level name in the message properties
CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Key name for the logger category name in the message properties
CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Key name for the logger category name in the message properties
CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
Key name for the logger category name in the message properties
causeChainHasImmediateAcknowledgeAmqpException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Traverse the cause chain and, if an ImmediateAcknowledgeAmqpException is found before an AmqpRejectAndDontRequeueException, return true.
ChannelAwareMessageListener - Interface in org.springframework.amqp.rabbit.core
A message listener that is aware of the Channel on which the message was received.
ChannelCallback<T> - Interface in org.springframework.amqp.rabbit.core
Basic callback for use in RabbitTemplate
ChannelListener - Interface in org.springframework.amqp.rabbit.connection
 
ChannelProxy - Interface in org.springframework.amqp.rabbit.connection
Subinterface of Channel to be implemented by Channel proxies.
checkMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Check the given message listener, throwing an exception if it does not correspond to a supported listener type.
clear() - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Clear resources for the current thread.
clearConfirmListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
clearConnectionListeners() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
clearDelegates() - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
clearDeliveryTags() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Clear the delivery tags when rolling back with an external transaction manager.
clearFlowListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
clearReturnListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
close() - Method in interface org.springframework.amqp.rabbit.connection.Connection
Close this connection and all its channels with the AMQP.REPLY_SUCCESS close code and message 'OK'.
close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
close() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
close(int, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
close() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
closeAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
closeChannel(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Close the given RabbitMQ Channel and ignore any thrown exception.
closeConnection(Connection) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Close the given RabbitMQ Connection and ignore any thrown exception.
closeMessageConsumer(Channel, Collection<String>, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
 
commitAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
commitIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Commit the Channel if not within a JTA transaction.
commitIfNecessary(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Perform a commit or message acknowledgement, as appropriate.
CompositeChannelListener - Class in org.springframework.amqp.rabbit.connection
 
CompositeChannelListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
CompositeConnectionListener - Class in org.springframework.amqp.rabbit.connection
 
CompositeConnectionListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
ConditionalRejectingErrorHandler - Class in org.springframework.amqp.rabbit.listener
ErrorHandler that conditionally wraps the Exception in an AmqpRejectAndDontRequeueException if the configured rejection strategy determines that the message is fatal and should not be requeued.
ConditionalRejectingErrorHandler() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
ConditionalRejectingErrorHandler(FatalExceptionStrategy) - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Create a handler with the supplied FatalExceptionStrategy implementation.
ConditionalRejectingErrorHandler.DefaultExceptionStrategy - Class in org.springframework.amqp.rabbit.listener
Default implementation of FatalExceptionStrategy.
configureListenerAdapter(MessagingMessageListenerAdapter) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Create a HandlerAdapter for this listener adapter.
configureListenerAdapter(MessagingMessageListenerAdapter) - Method in class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
 
configureRabbitConnectionFactory(RabbitConnectionFactoryBean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
configureRabbitListeners(RabbitListenerEndpointRegistrar) - Method in interface org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurer
Callback allowing a RabbitListenerEndpointRegistry and specific RabbitListenerEndpoint instances to be registered against the given RabbitListenerEndpointRegistrar.
confirm(CorrelationData, boolean, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
confirm(CorrelationData, boolean, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
Confirmation callback.
confirmSelect() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
Connection - Interface in org.springframework.amqp.rabbit.connection
 
ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
An interface based ConnectionFactory for creating Connections.
connectionFactory - Variable in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
ConnectionFactoryUtils - Class in org.springframework.amqp.rabbit.connection
Helper class for managing a Spring based Rabbit ConnectionFactory, in particular for obtaining transactional Rabbit resources for a given ConnectionFactory.
ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.amqp.rabbit.connection
Callback interface for resource creation.
ConnectionListener - Interface in org.springframework.amqp.rabbit.connection
 
ConnectionNameStrategy - Interface in org.springframework.amqp.rabbit.connection
A strategy to build an application-specific connection name, which can be displayed in the management UI if RabbitMQ server supports it.
ConnectionProxy - Interface in org.springframework.amqp.rabbit.connection
Subinterface of Connection to be implemented by Connection proxies.
ConsumerCancelledException - Exception in org.springframework.amqp.rabbit.support
Thrown when the broker cancels the consumer and the message queue is drained.
ConsumerCancelledException() - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
 
ConsumerCancelledException(Throwable) - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
 
ConsumerChannelRegistry - Class in org.springframework.amqp.rabbit.connection
Consumers register their primary channels with this class.
consumerCount(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
containsChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
convertAmqpException(RuntimeException) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAmqpMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given Object to serialized form, possibly using a MessageConverter, wrap it as a message and send it to a specific exchange with a specific routing key.
convertAndSend(String, String, Object, Map<String, Object>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given Object to serialized form, possibly using a MessageConverter, wrap it as a message with the given headers and send it to a specific exchange with a specific routing key.
convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given Object to serialized form, possibly using a MessageConverter, wrap it as a message, apply the given post processor, and send the resulting message to a specific exchange with a specific routing key.
convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given Object to serialized form, possibly using a MessageConverter, wrap it as a message with the given headers, apply the given post processor, and send the resulting message to a specific exchange with a specific routing key.
convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(String, String, Object, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertMessageIfNecessary(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertRabbitAccessException(Exception) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
convertRabbitAccessException(Throwable) - Static method in class org.springframework.amqp.rabbit.support.RabbitExceptionTranslator
 
convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the default exchange with the default routing key.
convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the default exchange with the provided routing key.
convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the provided exchange and routing key.
convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the default exchange with the default routing key after invoking the MessagePostProcessor.
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the default exchange with the provided routing key after invoking the MessagePostProcessor.
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Convert the object to a message and send it to the provided exchange and routing key after invoking the MessagePostProcessor.
convertSendAndReceive(String, String, Object, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given request Object to serialized form, possibly using a MessageConverter, send it as a Message to a specific exchange with a specific routing key, receive the reply and convert its body of the specified target class.
convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given request Object to serialized form, possibly using a MessageConverter, send it as a Message with the given headers, to a specific exchange with a specific routing key, receive the reply and convert its body of the specified target class.
convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given request Object to serialized form, possibly using a MessageConverter, apply the given post processor and send the resulting Message to a specific exchange with a specific routing key, receive the reply and convert its body of the given target class.
convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Convert the given request Object to serialized form, possibly using a MessageConverter, wrap it as a message with the given headers, apply the given post processor and send the resulting Message to a specific exchange with a specific routing key,, receive the reply and convert its body of the given target class.
convertSendAndReceive(String, String, Object, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveRaw(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Convert and send a message and return the raw reply message, or null.
correlationconvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Deprecated.
correlationConvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
CorrelationData - Class in org.springframework.amqp.rabbit.support
Base class for correlating publisher confirms to sent messages.
CorrelationData() - Constructor for class org.springframework.amqp.rabbit.support.CorrelationData
Construct an instance with a null Id.
CorrelationData(String) - Constructor for class org.springframework.amqp.rabbit.support.CorrelationData
Construct an instance with the supplied id.
CorrelationDataPostProcessor - Interface in org.springframework.amqp.rabbit.core
A callback invoked immediately before publishing a message to update, replace, or create correlation data for publisher confirms.
counter - Variable in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
createAppender(Configuration, String, Layout<? extends Serializable>, Filter, boolean, String, int, String, String, String, String, int, int, String, String, boolean, String, String, String, boolean, boolean, boolean, String, String, String, boolean, String) - Static method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
createBareConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
createBlockingQueueConsumer() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
createChannel(boolean) - Method in interface org.springframework.amqp.rabbit.connection.Connection
Create a new channel, using an internally allocated channel number.
createChannel(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Create a new RabbitMQ Session for registration with a RabbitResourceHolder.
createChannel(boolean) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
createClient(String, String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
Create a client instance.
createConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
createConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Create a new RabbitMQ Connection for registration with a RabbitResourceHolder.
createConnection() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
createConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Create a RabbitMQ Connection via this template's ConnectionFactory and its host and port values.
createConnectionFactory(String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
Create a dedicated connection factory for the address.
createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Create an empty container instance.
createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
createElementDescription(Element) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Provides a user friendly description of an element based on its node name and, if available, its "id" attribute value.
createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
createInstance() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
createInstance() - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
 
createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
createListenerContainer(RabbitListenerEndpoint) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
createListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Create and start a new MessageListenerContainer using the specified factory.
createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
 
createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Create a MessageListener that is able to serve this endpoint for the specified container.
createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
createMessageListenerInstance() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Create an empty MessagingMessageListenerAdapter instance.
createRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
Create the ConnectionFactory.
createRabbitTemplate(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Create a RabbitTemplate for the given ConnectionFactory.
createSSLContext() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Override this method to create and/or configure the SSLContext used by the ConnectionFactory.

D

DeclarationExceptionEvent - Class in org.springframework.amqp.rabbit.core
Application event published when a declaration exception occurs.
DeclarationExceptionEvent(Object, Declarable, Throwable) - Constructor for class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
declareBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
declareExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
DeclareExchangeConnectionListener - Class in org.springframework.amqp.rabbit.core
A ConnectionListener that will declare a single exchange when the connection is established.
DeclareExchangeConnectionListener(Exchange, RabbitAdmin) - Constructor for class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
 
declareQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Declare the given queue.
declareQueue() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Declares a server-named exclusive, autodelete, non-durable queue.
declareTransactional(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Declare to that broker that a channel is going to be used transactionally, and convert exceptions that arise.
DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
DEFAULT_DEBATCHING_ENABLED - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
DEFAULT_EXCHANGE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
The default exchange name.
DEFAULT_PORT - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
 
DEFAULT_PREFETCH_COUNT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
DEFAULT_RABBIT_LISTENER_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
The bean name of the default RabbitListenerContainerFactory.
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
The default recovery interval: 5000 ms = 5 seconds.
DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
DefaultExceptionStrategy() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
 
DefaultMessagePropertiesConverter - Class in org.springframework.amqp.rabbit.support
Default implementation of the MessagePropertiesConverter strategy.
DefaultMessagePropertiesConverter() - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
Construct an instance where LongStrings will be returned unconverted when longer than 1024 bytes.
DefaultMessagePropertiesConverter(int) - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
Construct an instance where LongStrings will be returned unconverted when longer than this limit.
DefaultMessagePropertiesConverter(int, boolean) - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
Construct an instance where LongStrings will be returned unconverted or as a DataInputStream when longer than this limit.
DefaultMessagePropertiesConverter.CorrelationIdPolicy - Enum in org.springframework.amqp.rabbit.support
Deprecated.
defaultRabbitListenerEndpointRegistry() - Method in class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
 
DelegatingInvocableHandler - Class in org.springframework.amqp.rabbit.listener.adapter
Delegates to an InvocableHandlerMethod based on the message payload type.
DelegatingInvocableHandler(List<InvocableHandlerMethod>, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Construct an instance with the supplied handlers for the bean.
deleteExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
deleteExchange(String, Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
deleteQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteQueue(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
deleteQueue(String, Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
Delivery - Class in org.springframework.amqp.rabbit.support
Encapsulates an arbitrary message - simple "bean" holder structure.
Delivery(String, Envelope, AMQP.BasicProperties, byte[]) - Constructor for class org.springframework.amqp.rabbit.support.Delivery
 
destroy() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
destroy() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Close the underlying shared connection.
destroy() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
destroy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Calls AbstractMessageListenerContainer.shutdown() when the BeanFactory destroys the container instance.
destroy() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
determineConfirmsReturnsCapability(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Determine the current lookup key.
determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
 
determineTargetConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Retrieve the current target ConnectionFactory.
DirectExchangeParser - Class in org.springframework.amqp.rabbit.config
 
DirectExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.DirectExchangeParser
 
doBegin(Object, TransactionDefinition) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doGetTransaction() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doInitialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Register any invokers within this container.
doInitialize() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Creates the specified number of concurrent consumers, in the form of a Rabbit Channel plus associated MessageConsumer.
doInRabbit(Channel) - Method in interface org.springframework.amqp.rabbit.core.ChannelCallback
Execute any number of operations against the supplied RabbitMQ Channel, possibly returning a result.
doInvokeListener(ChannelAwareMessageListener, Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the specified listener as Spring ChannelAwareMessageListener, exposing a new Rabbit Session (potentially with its own transaction) to the listener if demanded.
doInvokeListener(MessageListener, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the specified listener as Spring Rabbit MessageListener.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.QueueParser
 
doParseBindings(Element, ParserContext, String, Element, AbstractExchangeParser) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
doReceive(String) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doReceiveNoWait(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Non-blocking receive.
doResume(Object, Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doSend(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSend(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSend(Channel, String, String, Message, boolean, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Send the given message to the specified exchange.
doSendAndReceive(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Send a message and wait for a reply.
doSendAndReceiveWithFixed(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
doSendAndReceiveWithTemporary(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doShutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Close the registered invokers.
doShutdown() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
doStart() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Start this container, and notify all invoker tasks.
doStart() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Re-initializes this container's Rabbit message consumers, if not initialized already.
doStop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
This method is invoked when the container is stopping.
doStop() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
doSuspend(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 

E

EnableRabbit - Annotation Type in org.springframework.amqp.rabbit.annotation
Enable Rabbit listener annotated endpoints that are created under the cover by a RabbitListenerContainerFactory.
equals(Object) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
errorRoutingKeyPrefix(String) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
Apply a prefix to the outbound routing key, which will be prefixed to the original message routing key (if no explicit routing key was provided in the constructor; ignored otherwise.
Event(LoggingEvent, Map) - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
Deprecated.
 
Event(LogEvent, Map<?, ?>) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
Event(ILoggingEvent) - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
EventSender() - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender.EventSender
Deprecated.
 
EventSender() - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.EventSender
 
EventSender() - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender.EventSender
 
Exchange - Annotation Type in org.springframework.amqp.rabbit.annotation
An exchange to which to bind a RabbitListener queue.
exchangeBind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeBindNoWait(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclareNoWait(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclareNoWait(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDelete(String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDelete(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeleteNoWait(String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeUnbind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeUnbindNoWait(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
execute(ChannelCallback<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
 
execute(ChannelCallback<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
executeListener(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Execute the specified listener, committing or rolling back the transaction afterwards (if necessary).
expectedQueueNames() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Invoked by the container during startup so it can verify the queue is correctly configured (if a simple reply queue name is used instead of exchange/routingKey.
expectedQueueNames() - Method in interface org.springframework.amqp.rabbit.support.ListenerContainerAware
Return the queue names that the listener expects to listen to.
expire(PublisherCallbackChannel.Listener, long) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
Expire (remove) any PendingConfirms created before cutoffTime for the supplied listener and return them to the caller.
expire(PublisherCallbackChannel.Listener, long) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
ExpressionFactoryBean - Class in org.springframework.amqp.rabbit.support
FactoryBean for creating Expression instances.
ExpressionFactoryBean(String) - Constructor for class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
 
extractMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Extract the message body from the given Rabbit message.

F

FanoutExchangeParser - Class in org.springframework.amqp.rabbit.config
 
FanoutExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
FatalExceptionStrategy - Interface in org.springframework.amqp.rabbit.listener
A strategy interface for the ConditionalRejectingErrorHandler to decide whether an exception should be considered to be fatal and the message should not be requeued.
FatalListenerExecutionException - Exception in org.springframework.amqp.rabbit.listener.exception
Exception to be thrown when the execution of a listener method failed unrecoverably.
FatalListenerExecutionException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.FatalListenerExecutionException
Constructor for ListenerExecutionFailedException.
FatalListenerExecutionException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.FatalListenerExecutionException
Constructor for ListenerExecutionFailedException.
FatalListenerStartupException - Exception in org.springframework.amqp.rabbit.listener.exception
Exception to be thrown when the execution of a listener method failed on startup.
FatalListenerStartupException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.FatalListenerStartupException
Constructor for ListenerExecutionFailedException.
findHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
flowBlocked() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
Deprecated.
in the 3.5.3 client
flush() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
Flush any partial in-progress batches.
fromMessageProperties(MessageProperties, String) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
 
fromMessageProperties(MessageProperties, String) - Method in interface org.springframework.amqp.rabbit.support.MessagePropertiesConverter
 

G

get(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Retrieve a resource for the given key that is bound to the current thread.
getAcknowledgeMode() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getActiveConsumerCount() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
getAddress() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getAddresses() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getAddresses() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getAmqpMessageConverter() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
getApplicationContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getApplicationId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getApplicationId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getBackOffExecution() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
 
getBean() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.DirectExchangeParser
 
getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 
getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.QueueParser
 
getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.TopicExchangeParser
 
getBeanExpressionContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getBeanFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getBeanName() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
getBeanName() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getBeanResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getBindings() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getBindings(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getBindingsForExchange(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getBody() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the message body.
getCacheMode() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getCacheProperties() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getCause() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
 
getChannel(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Channel from the given RabbitResourceHolder.
getChannel(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Fetch an appropriate Channel from the given RabbitResourceHolder.
getChannel() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
getChannel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
getChannelCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getChannelListener() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
A composite channel listener to be used by subclasses when creating and closing channels.
getChannelNumber() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getCharset() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getCharset() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getClient() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getCloseReason() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getCloseTimeout() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getConfirm() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
When confirms are enabled contains a ListenableFuture for the confirmation.
getConnection(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Connection from the given RabbitResourceHolder.
getConnection(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Fetch an appropriate Connection from the given RabbitResourceHolder.
getConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
getConnection(Class<? extends Connection>) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
getConnection() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getConnectionCachesize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Deprecated.
getConnectionCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
getConnectionListener() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
A composite connection listener to be used by subclasses when creating and closing connections.
getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
 
getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
 
getConsumerChannel() - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
See registerConsumerChannel.
getConsumerChannel(ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
See registerConsumerChannel.
getConsumerTag() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
getConsumerTag() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the consumer tag.
getContentEncoding() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getContentEncoding() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getContentType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getContentType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getCorrelationData() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
The correlation data supplied by the client when sending the message corresponding to this confirmation.
getCount() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 
getDeclarable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
getDefaultConsumer() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getDefaultHostName() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getDefaultListenerMethod() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
 
getDelegate() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
 
getDelegate() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
Use this to invoke methods on the underlying rabbit client Channel that are not supported by this implementation.
getDelegate() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getDeliveryMode() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getDeliveryMode() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getEndpointDescription() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
 
getEndpointDescription() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getEndpointDescription() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getEndpointRegistry() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
getEnvelope() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the message envelope.
getEvent() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
Deprecated.
 
getEvent() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
getEvent() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
getExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getExchange(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getExchange() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getExchange() - Method in class org.springframework.amqp.rabbit.core.support.MessageBatch
 
getExchangeName() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getExchangeName() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getExchanges() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getExchanges(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getExchangeType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getExchangeType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getExecutorService() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getExpressionString() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getFailedMessage() - Method in exception org.springframework.amqp.rabbit.listener.exception.ListenerExecutionFailedException
 
getGroup() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getGroup() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
 
getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
getHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
getHost() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
getHost() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
getHost() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getHost() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getId() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getId() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
 
getId() - Method in class org.springframework.amqp.rabbit.support.CorrelationData
 
getIdleTime() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
How long the container has been idle.
getKey(Message) - Method in interface org.springframework.amqp.rabbit.retry.MessageKeyGenerator
Generate a unique key for the message that is repeatable on redelivery.
getKeyStore() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStorePassphrase() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStoreResource() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStoreType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
getLastDeclarationExceptionEvent() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getListenerContainer(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Return the MessageListenerContainer with the specified id or null if no such container exists.
getListenerContainerIds() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Return the ids of the managed MessageListenerContainer instance(s).
getListenerContainers() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
getListenerId() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
The 'id' attribute of the listener.
getListenerId() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
The id of the listener (if @RabbitListener) or the container bean name.
getListenerMethodName(Message, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Determine the name of the listener method that will handle the given message.
getLocalAddress() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getLocalPort() - Method in interface org.springframework.amqp.rabbit.connection.Connection
 
getLocalPort() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getMaxSenderRetries() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getMaxSenderRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getMessage() - Method in class org.springframework.amqp.rabbit.core.support.MessageBatch
 
getMessageConverter() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
getMessageConverter() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return the message converter for this template.
getMessageConverter() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getMessageConverter() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Return the converter that will convert incoming Rabbit messages to listener method arguments, and objects returned from listener methods back to Rabbit messages.
getMessageConverter() - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
 
getMessageHandlerMethodFactory() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getMessageHandlerMethodFactory() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
getMessageListener() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
 
getMessageListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getMessageRecoverer() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
getMessagingMessageConverter() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
getMethod() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getMethodAsString(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
 
getMethodNameFor(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Return a string representation of the method that will be invoked for this payload.
getNackCause() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
When confirms are enabled and a nack is received, contains the cause for the nack, if any.
getNewConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
getNextPublishSeqNo() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getObject() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
getObject() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
getObject() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
 
getOldConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
getOrder() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
getPassword() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getPassword() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getPhase() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
getPhase() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getPhase() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getPhase() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
getPort() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getPort() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
getPort() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
getPort() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
getPort() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getPort() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getPort() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getPriority() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getProperties() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
Deprecated.
 
getProperties() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
getProperties() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
getProperties() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the message properties.
getQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getQueue(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
The queues the container is listening to.
getQueueNamesAsSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getQueueProperties(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Returns 3 properties RabbitAdmin.QUEUE_NAME, RabbitAdmin.QUEUE_MESSAGE_COUNT, RabbitAdmin.QUEUE_CONSUMER_COUNT, or null if the queue doesn't exist.
getQueues() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getQueues(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
getQueues() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getRabbitAdmin() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
getRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Return a reference to the underlying Rabbit Connection factory.
getRabbitOperations() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
 
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
getReason() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
getReplyToAddress(Message, Object, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Determine a reply-to Address for the given message.
getRequest() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
 
getRequiredQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getResourceFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
getResources() - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Return all resources that are bound to the current thread.
getResult() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
 
getRetryOperations() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
getRoutingConnectionFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the (@link RoutingConnectionFactory} if the connection factory is a RoutingConnectionFactory; null otherwise.
getRoutingKey() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getRoutingKey() - Method in class org.springframework.amqp.rabbit.core.support.MessageBatch
 
getRoutingKeyPattern() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getRoutingKeyPattern() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getRoutingLookupKey() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the lookup key if the connection factory is a RoutingConnectionFactory; null otherwise.
getSecureRandom() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getSenderPoolSize() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getSenderPoolSize() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getSource() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
 
getSslAlgorithm() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getSslPropertiesLocation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTargetChannel() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
Return the target Channel of this proxy.
getTargetConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionProxy
Return the target Channel of this proxy.
getTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
getTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
getTargetConnectionFactory(Object) - Method in interface org.springframework.amqp.rabbit.connection.RoutingConnectionFactory
Returns the ConnectionFactory bound to given lookup key, or null if one does not exist
getThrowable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
getThrowable() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
getTimestamp() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
 
getTransactionalResourceHolder(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.
getTransactionalResourceHolder() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
getTrustStore() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStorePassphrase() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStoreResource() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStoreType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
getUnconfirmed(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Gets unconfirmed correlation data older than age and removes them.
getUsername() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Return the user name from the underlying rabbit connection factory.
getUsername() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
getUsername() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
getUsername() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
getUsername() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getUsername() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getUUID() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getUUID() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
Returns the UUID used to identify this Listener for returns.
getValue() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueType() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueType(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueTypeDescriptor() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
getVirtualHost() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 

H

handleAck(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
handleConfirm(PendingConfirm, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleConfirm(PendingConfirm, boolean) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
Invoked by the channel when a confirm is received.
handleError(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
 
handleListenerException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Handle the given exception that arose during listener execution.
handleListenerException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Handle the given exception that arose during listener execution.
handleNack(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
HandlerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
A wrapper for either an InvocableHandlerMethod or DelegatingInvocableHandler.
HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
 
HandlerAdapter(DelegatingInvocableHandler) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
 
handleResult(Object, Message, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Handle the given result object returned from the listener method, sending a response message back.
handleResult(Object, Message, Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Handle the given result object returned from the listener method, sending a response message back.
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
 
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
handleStartupFailure(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Wait for a period determined by the recoveryInterval or SimpleMessageListenerContainer.setRecoveryBackOff(BackOff) to give the container a chance to recover from consumer startup failure, e.g.
has(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Check if there is a resource for the given key bound to the current thread.
hasDelivery() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
hashCode() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
HeadersExchangeParser - Class in org.springframework.amqp.rabbit.config
 
HeadersExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 

I

incrementRetries() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
Deprecated.
 
incrementRetries() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
incrementRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
init() - Method in class org.springframework.amqp.rabbit.config.RabbitNamespaceHandler
 
initDefaultStrategies() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set up the default strategies.
initGateway() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Subclasses can override this for custom initialization behavior.
initialize() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Declares all the exchanges, queues and bindings in the enclosing application context, if any.
initialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Initialize this container.
initializeConsumers() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
initializeContainer(C) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Further initialize the specified container.
initializeContainer(SimpleMessageListenerContainer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
invoke(Message<?>, Object...) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Invoke the method with the given message.
invoke(Message<?>, Object...) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
 
invoke(MethodInvocation) - Method in class org.springframework.amqp.rabbit.retry.MissingMessageIdAdvice
 
invokeErrorHandler(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the registered ErrorHandler, if any.
invokeListener(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the specified listener: either as standard MessageListener or (preferably) as SessionAwareMessageListener.
invokeListener(Channel, Message) - Method in interface org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer.ContainerDelegate
 
invokeListener(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
invokeListenerMethod(String, Object[]) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
invokeListenerMethod(String, Object[], Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Invoke the specified listener method.
isActive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isAttributeDefined(Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Checks the attribute to see if it is defined in the given element.
isAutoDelete() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
isAutoDelete() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this template's Channel handling and not by an external transaction coordinator.
isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this listener container's Channel handling and not by an external transaction coordinator.
isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
isChannelTransacted() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
isChannelTransactional(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
Determine whether the given RabbitMQ Channel is transactional, that is, bound to the current thread by Spring's transaction facilities.
isChannelTransactional() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Deprecated.
Not used
isConfirmListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
isConfirmListener() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
 
isDeclareExchange() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
isDeclareExchange() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isDurable() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
isDurable() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isExchangeDeclarationFailure(Exception) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if there is a ShutdownSignalException in the cause tree and its reason is "COMMAND_INVALID" and the operation being performed was exchangeDeclare.
isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
isExclusiveUseChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if the ShutdownSignalException reason is AMQP.Channel.Close and the operation that failed was basicConsumer and the failure text contains "exclusive".
isExistingTransaction(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
isExposeListenerChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
 
isFatal(Throwable) - Method in interface org.springframework.amqp.rabbit.listener.FatalExceptionStrategy
 
isFatal() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
isFrozen() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
isGenerateId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
isGenerateId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isIncludeCallerData() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isLenientFallback() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
isMismatchedQueueArgs(Exception) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if there is a ShutdownSignalException in the cause tree and its reason is "PRECONDITION_FAILED" and the operation being performed was queueDeclare.
isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
Query a message to see if it has been seen before.
isNormalCancel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Return true if cancellation is expected.
isNormalChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if the ShutdownSignalException reason is AMQP.Channel.Close and the reply code was AMQP.REPLY_SUCCESS (200) and the text equals "OK".
isNormalShutdown(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if the ShutdownSignalException reason is AMQP.Connection.Close and the reply code was AMQP.REPLY_SUCCESS (200) and the text equals "OK".
isOpen() - Method in interface org.springframework.amqp.rabbit.connection.Connection
Flag to indicate the status of the connection.
isOpen() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
True if the connection is open.
isOpen() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
isPassiveDeclarationChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return true if the ShutdownSignalException reason is AMQP.Channel.Close and the operation that failed was exchangeDeclare or queueDeclare.
isPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Gets and removes a ThreadLocal indicating the channel MUST be physically closed.
isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelConnectionFactory
 
isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isPublisherReturns() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelConnectionFactory
 
isReleaseAfterCompletion() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Whether the resources should be released after transaction completion.
isReturnListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
isReturnListener() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
 
isRunning() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
isRunning() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isRunning() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
isRunning() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Determine whether this container is currently running, that is, whether it has been started and not stopped yet.
isRunning() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
isSingleton() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
isSingleton() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
 
isSkipServerCertificateValidation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not Server Side certificate has to be validated or not.
isSynchedLocalTransactionAllowed() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Return whether to allow for a local RabbitMQ transaction that is synchronized with a Spring-managed transaction (where the main transaction might be a JDBC-based one for a specific DataSource, for example), with the RabbitMQ transaction committing right after the main transaction.
isTransactional() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
Return whether this channel has transactions enabled txSelect().
isUserCauseFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
Subclasses can override this to add custom exceptions.
isUseSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
isWritable(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
isWritable(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 

L

ListenerContainerAware - Interface in org.springframework.amqp.rabbit.support
MessageListeners and ChannelAwareMessageListeners that also implement this interface can have configuration verified during initialization.
ListenerContainerConsumerFailedEvent - Class in org.springframework.amqp.rabbit.listener
Published when a listener consumer fails.
ListenerContainerConsumerFailedEvent(Object, String, Throwable, boolean) - Constructor for class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
Construct an instance with the provided arguments.
ListenerContainerIdleEvent - Class in org.springframework.amqp.rabbit.listener
An event that is emitted when a container is idle if the container is configured to do so.
ListenerContainerIdleEvent(Object, long, String, String...) - Constructor for class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
 
ListenerExecutionFailedException - Exception in org.springframework.amqp.rabbit.listener.exception
Exception to be thrown when the execution of a listener method failed.
ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.ListenerExecutionFailedException
ListenerExecutionFailedException(String, Throwable, Message) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.ListenerExecutionFailedException
Constructor for ListenerExecutionFailedException.
ListenerFailedRuleBasedTransactionAttribute - Class in org.springframework.amqp.rabbit.transaction
Subclass of RuleBasedTransactionAttribute that is aware that listener exceptions are wrapped in ListenerExecutionFailedExceptions.
ListenerFailedRuleBasedTransactionAttribute() - Constructor for class org.springframework.amqp.rabbit.transaction.ListenerFailedRuleBasedTransactionAttribute
 
LocalizedQueueConnectionFactory - Class in org.springframework.amqp.rabbit.connection
A RoutingConnectionFactory that determines the node on which a queue is located and returns a factory that connects directly to that node.
LocalizedQueueConnectionFactory(ConnectionFactory, Map<String, String>, String[], String, String, String, boolean, Resource) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
LocalizedQueueConnectionFactory(ConnectionFactory, Map<String, String>, String[], String, String, String, boolean, String, String, String, String) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
LocalizedQueueConnectionFactory(ConnectionFactory, String[], String[], String[], String, String, String, boolean, Resource) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
LocalizedQueueConnectionFactory(ConnectionFactory, String[], String[], String[], String, String, String, boolean, String, String, String, String) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
LogAppenderUtils - Class in org.springframework.amqp.rabbit.support
Utility methods for log appenders.
logger - Variable in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
logger - Variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
logger - Variable in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
 
logger - Variable in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
 
logger - Variable in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
logger - Variable in class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
 

M

matchHandlerMethod(Class<? extends Object>, InvocableHandlerMethod) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
maxAttempts(int) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the max attempts - a SimpleRetryPolicy will be used.
maxAttempts(int) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
maybeDeclareExchange() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
maybeDeclareExchange() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
MessageBatch - Class in org.springframework.amqp.rabbit.core.support
An object encapsulating a Message containing the batch of messages, the exchange, and routing key.
MessageBatch(String, String, Message) - Constructor for class org.springframework.amqp.rabbit.core.support.MessageBatch
 
messageCount(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
messageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
Stateful retry requires messages to be identifiable.
MessageKeyGenerator - Interface in org.springframework.amqp.rabbit.retry
 
MessageListenerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with flexible message type conversion.
MessageListenerAdapter() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter with default settings.
MessageListenerAdapter(Object) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
MessageListenerAdapter(Object, MessageConverter) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
MessageListenerAdapter(Object, String) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate while also declaring its POJO method.
MessageListenerContainer - Interface in org.springframework.amqp.rabbit.listener
Internal abstraction used by the framework representing a message listener container.
MessagePropertiesConverter - Interface in org.springframework.amqp.rabbit.support
Strategy interface for converting between Spring AMQP MessageProperties and RabbitMQ BasicProperties.
MessageRecoverer - Interface in org.springframework.amqp.rabbit.retry
 
MessageRejectedWhileStoppingException - Exception in org.springframework.amqp.rabbit.listener
Exception class that indicates a rejected message on shutdown.
MessageRejectedWhileStoppingException() - Constructor for exception org.springframework.amqp.rabbit.listener.MessageRejectedWhileStoppingException
 
MessagingMessageListenerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
A MessageListener adapter that invokes a configurable HandlerAdapter.
MessagingMessageListenerAdapter() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
MessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
MethodRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.listener
A RabbitListenerEndpoint providing the method to invoke to process an incoming message for this endpoint.
MethodRabbitListenerEndpoint() - Constructor for class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
MissingMessageIdAdvice - Class in org.springframework.amqp.rabbit.retry
Advice that can be placed in the listener delegate's advice chain to enhance the message with an ID if not present.
MissingMessageIdAdvice(RetryContextCache) - Constructor for class org.springframework.amqp.rabbit.retry.MissingMessageIdAdvice
 
MultiMethodRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.listener
 
MultiMethodRabbitListenerEndpoint(List<Method>, Object) - Constructor for class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
 

N

NamespaceUtils - Class in org.springframework.amqp.rabbit.config
Shared utility methods for namespace parsers.
NamespaceUtils() - Constructor for class org.springframework.amqp.rabbit.config.NamespaceUtils
 
newMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
Apply a custom new message identifier.
NewMessageIdentifier - Interface in org.springframework.amqp.rabbit.retry
An optimization for stateful retry of message processing.
nextMessage() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Main application-side API: wait for the next message delivery and return it.
nextMessage(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Main application-side API: wait for the next message delivery and return it.
nextRelease() - Method in interface org.springframework.amqp.rabbit.core.support.BatchingStrategy
 
nextRelease() - Method in class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
 
notifyListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 

O

obtainNewConnectionName(ConnectionFactory) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionNameStrategy
 
onApplicationEvent(ContextClosedEvent) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
onClose(Connection) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onClose(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
 
onClose(Connection) - Method in class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
 
onCreate(Channel, boolean) - Method in interface org.springframework.amqp.rabbit.connection.ChannelListener
 
onCreate(Channel, boolean) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
onCreate(Connection) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onCreate(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
 
onCreate(Connection) - Method in class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
onMessage(Message, Channel) - Method in interface org.springframework.amqp.rabbit.core.ChannelAwareMessageListener
Callback for processing a received Rabbit message.
onMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Rabbit MessageListener entry point.
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Spring ChannelAwareMessageListener entry point.
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
ORDER - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
org.springframework.amqp.rabbit - package org.springframework.amqp.rabbit
Provides top-level classes for Spring Rabbit.
org.springframework.amqp.rabbit.annotation - package org.springframework.amqp.rabbit.annotation
Annotations and supporting classes for declarative Rabbit listener endpoint
org.springframework.amqp.rabbit.config - package org.springframework.amqp.rabbit.config
Provides classes supporting the Rabbit XML namespace.
org.springframework.amqp.rabbit.connection - package org.springframework.amqp.rabbit.connection
Provides classes related to connections.
org.springframework.amqp.rabbit.core - package org.springframework.amqp.rabbit.core
Provides core classes for Spring Rabbit.
org.springframework.amqp.rabbit.core.support - package org.springframework.amqp.rabbit.core.support
Provides core support classes for Spring Rabbit.
org.springframework.amqp.rabbit.listener - package org.springframework.amqp.rabbit.listener
Provides classes for message listener containers.
org.springframework.amqp.rabbit.listener.adapter - package org.springframework.amqp.rabbit.listener.adapter
Provides classes for adapting listeners.
org.springframework.amqp.rabbit.listener.exception - package org.springframework.amqp.rabbit.listener.exception
Provides classes for listener exceptions.
org.springframework.amqp.rabbit.log4j - package org.springframework.amqp.rabbit.log4j
Provides classes supporting Log4J appenders.
org.springframework.amqp.rabbit.log4j2 - package org.springframework.amqp.rabbit.log4j2
Provides classes supporting Log4j 2 appenders.
org.springframework.amqp.rabbit.logback - package org.springframework.amqp.rabbit.logback
Provides classes supporting Logback appenders.
org.springframework.amqp.rabbit.retry - package org.springframework.amqp.rabbit.retry
Provides classes supporting retries.
org.springframework.amqp.rabbit.support - package org.springframework.amqp.rabbit.support
Provides support classes for Spring Rabbit.
org.springframework.amqp.rabbit.transaction - package org.springframework.amqp.rabbit.transaction
Provides classes supporting transactions in Spring Rabbit.
ORIGINAL_DEFAULT_LISTENER_METHOD - Static variable in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Out-of-the-box value for the default listener method: "handleMessage".

P

parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.DirectExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.TopicExchangeParser
 
parseBindings(Element, ParserContext, BeanDefinitionBuilder, String) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseContainer(Element, ParserContext) - Static method in class org.springframework.amqp.rabbit.config.RabbitNamespaceUtils
 
parseDeclarationControls(Element, BeanDefinitionBuilder) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Parses 'auto-declare' and 'declared-by' attributes.
parseDestination(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseInnerBeanDefinition(Element, ParserContext) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
PendingConfirm - Class in org.springframework.amqp.rabbit.support
Instances of this object track pending publisher confirms.
PendingConfirm(CorrelationData, long) - Constructor for class org.springframework.amqp.rabbit.support.PendingConfirm
 
postProcess(Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.CorrelationDataPostProcessor
Update or replace the correlation data provided in the send method.
postProcessAfterInitialization(Object, String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
postProcessChannel(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Post-process the given message before sending the response.
postProcessMessageBeforeSend(Message, AmqpAppender.Event) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Subclasses may modify the final message before sending.
postProcessMessageBeforeSend(Message, AmqpAppender.Event) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Subclasses may modify the final message before sending.
postProcessMessageBeforeSend(Message, AmqpAppender.Event) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Subclasses may modify the final message before sending.
postProcessResponse(Message, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Post-process the given response message before it will be sent.
processAmqpListener(RabbitListener, Method, Object, String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
processListener(MethodRabbitListenerEndpoint, RabbitListener, Object, Object, String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
PublisherCallbackChannel - Interface in org.springframework.amqp.rabbit.support
Instances of this interface support a single listener being registered for publisher confirms with multiple channels, by adding context to the callbacks.
PublisherCallbackChannel.Listener - Interface in org.springframework.amqp.rabbit.support
Listeners implementing this interface can participate in publisher confirms received from multiple channels, by invoking addListener on each channel.
PublisherCallbackChannelConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
Connection factories implementing this interface return a connection that provides PublisherCallbackChannel channel instances when confirms or returns are enabled.
PublisherCallbackChannelImpl - Class in org.springframework.amqp.rabbit.support
Channel wrapper to allow a single listener able to handle confirms from multiple channels.
PublisherCallbackChannelImpl(Channel) - Constructor for class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
purgeQueue(String, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
purgeQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 
purgeQueue(String, Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
 

Q

Queue - Annotation Type in org.springframework.amqp.rabbit.annotation
A queue definition used within the bindings attribute of a QueueBinding.
QUEUE_CONSUMER_COUNT - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
Property key for the consumer count in the Properties returned by RabbitAdmin.getQueueProperties(String).
QUEUE_MESSAGE_COUNT - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
Property key for the message count in the Properties returned by RabbitAdmin.getQueueProperties(String).
QUEUE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
Property key for the queue name in the Properties returned by RabbitAdmin.getQueueProperties(String).
queueBind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
QueueBinding - Annotation Type in org.springframework.amqp.rabbit.annotation
Defines a queue, the exchange it is to be bound to, and an optional binding key; used with @RabbitListener.
queueBindNoWait(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclare() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclare(String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclareNoWait(String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDelete(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDelete(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeleteNoWait(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
QueueParser - Class in org.springframework.amqp.rabbit.config
 
QueueParser() - Constructor for class org.springframework.amqp.rabbit.config.QueueParser
 
queuePurge(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
QueuesNotAvailableException - Exception in org.springframework.amqp.rabbit.listener
This exception indicates that a consumer could not be started because none of its queues are available for listening.
QueuesNotAvailableException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.QueuesNotAvailableException
 
queueUnbind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 

R

RABBIT_EMPTY_STRING_ARGUMENTS_PROPERTY - Static variable in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
RABBIT_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The bean name of the internally managed Rabbit listener annotation processor.
RABBIT_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The bean name of the internally managed Rabbit listener endpoint registry.
RabbitAccessor - Class in org.springframework.amqp.rabbit.connection
 
RabbitAccessor() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
RabbitAdmin - Class in org.springframework.amqp.rabbit.core
RabbitMQ implementation of portable AMQP administrative operations for AMQP >= 0.9.1
RabbitAdmin(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdmin
 
RabbitAdminEvent - Class in org.springframework.amqp.rabbit.core
Base class for admin events.
RabbitAdminEvent(Object) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdminEvent
 
RabbitBootstrapConfiguration - Class in org.springframework.amqp.rabbit.annotation
@Configuration class that registers a RabbitListenerAnnotationBeanPostProcessor bean capable of processing Spring's @RabbitListener annotation.
RabbitBootstrapConfiguration() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
 
RabbitConnectionFactoryBean - Class in org.springframework.amqp.rabbit.connection
Factory bean to create a RabbitMQ ConnectionFactory, delegating most setter methods and optionally enabling SSL, with or without certificate validation.
RabbitConnectionFactoryBean() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
RabbitConverterFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
 
RabbitExceptionTranslator - Class in org.springframework.amqp.rabbit.support
Translates Rabbit Exceptions to the AmqpException class hierarchy.
RabbitFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
 
RabbitGatewaySupport - Class in org.springframework.amqp.rabbit.core
Convenient super class for application classes that need RabbitMQ access.
RabbitGatewaySupport() - Constructor for class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
 
RabbitHandler - Annotation Type in org.springframework.amqp.rabbit.annotation
Annotation that marks a method to be the target of a Rabbit message listener within a class that is annotated with RabbitListener.
RabbitListener - Annotation Type in org.springframework.amqp.rabbit.annotation
Annotation that marks a method to be the target of a Rabbit message listener on the specified RabbitListener.queues() (or RabbitListener.bindings()).
RabbitListenerAnnotationBeanPostProcessor - Class in org.springframework.amqp.rabbit.annotation
Bean post-processor that registers methods annotated with RabbitListener to be invoked by a AMQP message listener container created under the cover by a RabbitListenerContainerFactory according to the parameters of the annotation.
RabbitListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
rabbitListenerAnnotationProcessor() - Method in class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
 
RabbitListenerConfigurer - Interface in org.springframework.amqp.rabbit.annotation
Optional interface to be implemented by Spring managed bean willing to customize how Rabbit listener endpoints are configured.
RabbitListenerConfigUtils - Class in org.springframework.amqp.rabbit.config
Configuration constants for internal sharing across subpackages.
RabbitListenerConfigUtils() - Constructor for class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
 
RabbitListenerContainerFactory<C extends MessageListenerContainer> - Interface in org.springframework.amqp.rabbit.listener
Factory of MessageListenerContainer based on a RabbitListenerEndpoint definition.
RabbitListenerEndpoint - Interface in org.springframework.amqp.rabbit.listener
Model for a Rabbit listener endpoint.
RabbitListenerEndpointRegistrar - Class in org.springframework.amqp.rabbit.listener
Helper bean for registering RabbitListenerEndpoint with a RabbitListenerEndpointRegistry.
RabbitListenerEndpointRegistrar() - Constructor for class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
RabbitListenerEndpointRegistry - Class in org.springframework.amqp.rabbit.listener
Creates the necessary MessageListenerContainer instances for the registered endpoints.
RabbitListenerEndpointRegistry() - Constructor for class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
RabbitListeners - Annotation Type in org.springframework.amqp.rabbit.annotation
Container annotation that aggregates several RabbitListener annotations.
RabbitManagementTemplate - Class in org.springframework.amqp.rabbit.core
A convenience wrapper for the RabbitMQ Client providing convenient access to the REST methods using the familiar Spring AMQP domain objects for Queue, Exchange and Binding.
RabbitManagementTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
Construct a template using uri "localhost:15672/api/" and user guest/guest.
RabbitManagementTemplate(Client) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
Construct a template using the supplied client.
RabbitManagementTemplate(String) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
Construct a template using the supplied uri.
RabbitManagementTemplate(String, String, String) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
Construct a template using the supplied uri.
RabbitMessageFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitMessageFuture
 
RabbitMessageOperations - Interface in org.springframework.amqp.rabbit.core
A specialization of MessageSendingOperations and MessageRequestReplyOperations for AMQP related operations that allow to specify not only the exchange but also the routing key to use.
RabbitMessagingTemplate - Class in org.springframework.amqp.rabbit.core
An implementation of RabbitMessageOperations.
RabbitMessagingTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
Constructor for use with bean properties.
RabbitMessagingTemplate(RabbitTemplate) - Constructor for class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
Create an instance with the RabbitTemplate to use.
RabbitNamespaceHandler - Class in org.springframework.amqp.rabbit.config
Namespace handler for Rabbit.
RabbitNamespaceHandler() - Constructor for class org.springframework.amqp.rabbit.config.RabbitNamespaceHandler
 
RabbitNamespaceUtils - Class in org.springframework.amqp.rabbit.config
 
RabbitOperations - Interface in org.springframework.amqp.rabbit.core
Rabbit specific methods for Amqp functionality.
RabbitResourceHolder - Class in org.springframework.amqp.rabbit.connection
Rabbit resource holder, wrapping a RabbitMQ Connection and Channel.
RabbitResourceHolder() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Create a new RabbitResourceHolder that is open for resources to be added.
RabbitResourceHolder(Channel, boolean) - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Construct an instance for the channel.
RabbitTemplate - Class in org.springframework.amqp.rabbit.core
Helper class that simplifies synchronous RabbitMQ access (sending and receiving messages).
RabbitTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
Convenient constructor for use with setter injection.
RabbitTemplate(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
Create a rabbit template with default strategies and settings.
RabbitTemplate.ConfirmCallback - Interface in org.springframework.amqp.rabbit.core
 
RabbitTemplate.ReturnCallback - Interface in org.springframework.amqp.rabbit.core
 
RabbitTransactionManager - Class in org.springframework.amqp.rabbit.transaction
PlatformTransactionManager implementation for a single Rabbit ConnectionFactory.
RabbitTransactionManager() - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
Create a new RabbitTransactionManager for bean-style usage.
RabbitTransactionManager(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
Create a new RabbitTransactionManager, given a ConnectionFactory.
RabbitUtils - Class in org.springframework.amqp.rabbit.connection
 
RabbitUtils() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitUtils
 
receive() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receive(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receive(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receive(String, long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(String, long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(ReceiveAndReplyCallback<R, S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(String, ReceiveAndReplyCallback<R, S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(ReceiveAndReplyCallback<R, S>, String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(String, ReceiveAndReplyCallback<R, S>, String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(String, ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
recover(Message, Throwable) - Method in interface org.springframework.amqp.rabbit.retry.MessageRecoverer
Callback for message that was consumed but failed all retry attempts.
recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
 
recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
recoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply a Message recoverer - default is to log and discard after retry is exhausted.
recoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
redeclareElementsIfNecessary() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Use RabbitAdmin.initialize() to redeclare everything if necessary.
REF_ATTRIBUTE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
registerAllEndpoints() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
registerConsumerChannel(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
If a listener container is configured to use a RabbitTransactionManager, the consumer's channel is registered here so that it is used as the bound resource when the transaction actually starts.
registerDeliveryTag(ConnectionFactory, Channel, Long) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
 
registerEndpoint(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Register a new RabbitListenerEndpoint alongside the RabbitListenerContainerFactory to use to create the underlying container.
registerEndpoint(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Register a new RabbitListenerEndpoint using the default RabbitListenerContainerFactory to create the underlying container.
registerListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Create a message listener container for the given RabbitListenerEndpoint.
registerListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>, boolean) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Create a message listener container for the given RabbitListenerEndpoint.
RejectAndDontRequeueRecoverer - Class in org.springframework.amqp.rabbit.retry
MessageRecover that causes the listener container to reject the message without requeuing.
RejectAndDontRequeueRecoverer() - Constructor for class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
 
release(T) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 
releaseBatches() - Method in interface org.springframework.amqp.rabbit.core.support.BatchingStrategy
Release batch(es), perhaps due to a timeout.
releaseBatches() - Method in class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
 
releaseResources(RabbitResourceHolder) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
 
releaseSub(long, TimeUnit) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
 
removeBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
removeConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
removeConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
removeDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
removeFlowListener(FlowListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Remove queue(s) from this container's list of queues.
removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Remove queues from this container's list of queues.
removeQueueOrTagToMethodName(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Remove the mapping of a queue name or consumer tag to a method name.
removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Remove queue(s) from this container's list of queues.
removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Remove queue(s) from this container's list of queues.
removeReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
removeShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
removeTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Removes the ConnectionFactory associated with the given lookup key and returns it.
ReplyExpressionRoot(Message, Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
 
ReplyFailureException - Exception in org.springframework.amqp.rabbit.listener.adapter
Exception to be thrown when the reply of a message failed to be sent.
ReplyFailureException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.adapter.ReplyFailureException
 
RepublishMessageRecoverer - Class in org.springframework.amqp.rabbit.retry
MessageRecoverer implementation that republishes recovered messages to a specified exchange with the exception stack trace stored in the message header x-exception.
RepublishMessageRecoverer(AmqpTemplate) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
RepublishMessageRecoverer(AmqpTemplate, String) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
RepublishMessageRecoverer(AmqpTemplate, String, String) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
requiresLayout() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
reset(List<ChannelProxy>, List<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
reset() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 
resetConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Close the connection(s).
ResultHolder(Object, Expression) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ResultHolder
 
RetryInterceptorBuilder<T extends org.aopalliance.intercept.MethodInterceptor> - Class in org.springframework.amqp.rabbit.config
Simplified facade to make it easier and simpler to build a StatefulRetryOperationsInterceptor or (stateless) RetryOperationsInterceptor by providing a fluent interface to defining the behavior on error.
RetryInterceptorBuilder.StatefulRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
 
RetryInterceptorBuilder.StatelessRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
 
retryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the retry operations - once this is set, other properties can no longer be set; can't be set if other properties have been applied.
retryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
retryPolicy(RetryPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the retry policy - cannot be used if a custom retry template has been provided, or the max attempts or back off options or policy have been applied.
retryPolicy(RetryPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
 
RETURN_CORRELATION_KEY - Static variable in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
 
returnedMessage(Message, int, String, String, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
returnedMessage(Message, int, String, String, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnCallback
Returned message callback.
revoke(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
revoke(Channel) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
When called, this listener should remove all references to the channel - it will no longer be invoked by the channel.
rollbackAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
rollbackIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
 
rollbackOn(Throwable) - Method in class org.springframework.amqp.rabbit.transaction.ListenerFailedRuleBasedTransactionAttribute
 
rollbackOnExceptionIfNecessary(Throwable) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Perform a rollback, handling rollback exceptions properly.
RoutingConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
Implementations select a connection factory based on a supplied key.
rpc(Method) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
run() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.EventSender
Deprecated.
 
run() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.EventSender
 
run() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.EventSender
 

S

send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
send(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Send a message to a specific exchange with a specific routing key.
send(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
send(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
send(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
send(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Send a message to the default exchange with the default routing key.
sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Send a message to the default exchange with the supplied routing key.
sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Send a message to the supplied exchange and routing key.
sendAndReceive(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
Send a request message to a specific exchange with a specific routing key and wait for the reply
sendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendResponse(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Send the given response message to the given destination.
setAbbreviation(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Flag controlling the behaviour of the container with respect to message acknowledgement.
setAddresses(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set addresses for clustering.
setAddresses(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setAddresses(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the RabbitAdmin instance to use.
setAdminsThatShouldDeclare(AmqpAdmin...) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Public setter for the Advice to apply to listener executions.
setAfterReceivePostProcessor(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set a MessagePostProcessor that will be invoked immediately after a Channel#basicGet() and before any message conversion is performed.
setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set MessagePostProcessors that will be applied after message reception, before invoking the MessageListener.
setAlwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set to false to avoid always requeuing on transaction rollback with an external TransactionManager.
setAmqpMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
Set the MessageConverter to use to convert a Message from the messaging to and from a Message.
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
setApplicationId(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setApplicationId(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAutomaticRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set to true to enable amqp-client automatic recovery.
setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set whether to automatically start the container after initialization.
setBackOffExecution(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the BackOffExecution to use for the recovery in the SimpleMessageListenerContainer.
setBean(Object) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Set the object instance that should manage this endpoint.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
Making a BeanFactory available is optional; if not set, RabbitListenerConfigurer beans won't get autodetected and an endpoint registry has to be explicitly configured.
setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
A BeanFactory only needs to be available in conjunction with RabbitListenerEndpointRegistrar.setContainerFactoryBeanName(java.lang.String).
setBeanName(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setBeanResolver(BeanResolver) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set a bean resolver for runtime SpEL expressions.
setBeforePublishPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set MessagePostProcessors that will be invoked immediately before invoking Channel#basicPublish(), after all other processing, except creating the AMQP.BasicProperties from MessageProperties.
setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setCause(String) - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
When the confirmation is nacked, set the cause when available.
setChannelCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
The number of channels to maintain in the cache.
setChannelCheckoutTimeout(long) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Sets the channel checkout timeout.
setChannelListeners(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setChannelTransacted(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Flag to indicate that channels created by this component will be transactional.
setCharset(Charset) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Deprecated.
- will be removed in 2.0 when byte[] correlation id is removed
setCharset(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setCharset(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Set additional client connection properties to be added to the rabbit connection, with the form key:value[,key:value]....
setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Set additional client connection properties to be added to the rabbit connection, with the form key:value[,key:value]....
setClientProperties(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Add custom client properties.
setCloseExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Set the strategy for logging close exceptions; by default, if a channel is closed due to a failed passive queue declaration, it is logged at debug level.
setCloseTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
How long to wait (milliseconds) for a response to a connection close operation from the broker; default 30000 (30 seconds).
setConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Specify the number of concurrent consumers to create.
setConfirmCallback(RabbitTemplate.ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setConnectionCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Set the ConnectionFactory to use for obtaining RabbitMQ Connections.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Set the Rabbit connection factory to be used by the gateway.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
setConnectionLimit(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Set the connection limit when using cache mode CONNECTION.
setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setConnectionNameStrategy(ConnectionNameStrategy) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Provide a ConnectionNameStrategy to build the name for the target RabbitMQ connection.
setConnectionThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set the ThreadFactory on the underlying rabbit connection factory.
setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setConsecutiveActiveTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
If SimpleMessageListenerContainer.maxConcurrentConsumers is greater then SimpleMessageListenerContainer.concurrentConsumers, and SimpleMessageListenerContainer.maxConcurrentConsumers has not been reached, specifies the number of consecutive cycles when a single consumer was active, in order to consider starting a new consumer.
setConsecutiveIdleTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
If SimpleMessageListenerContainer.maxConcurrentConsumers is greater then SimpleMessageListenerContainer.concurrentConsumers, and the number of consumers exceeds SimpleMessageListenerContainer.concurrentConsumers, specifies the number of consecutive receive attempts that return no data; after which we consider stopping a consumer.
setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the implementation of ConsumerTagStrategy to generate consumer tags.
setContainerFactory(RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Set the RabbitListenerContainerFactory to use in case a RabbitListenerEndpoint is registered with a null container factory.
setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
Set the name of the RabbitListenerContainerFactory to use by default.
setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Set the bean name of the RabbitListenerContainerFactory to use in case a RabbitListenerEndpoint is registered with a null container factory.
setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setContentType(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setContentType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setCorrelationDataPostProcessor(CorrelationDataPostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set a CorrelationDataPostProcessor to be invoked before publishing a message.
setCorrelationIdAsString(DefaultMessagePropertiesConverter.CorrelationIdPolicy) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
Deprecated.
- the byte[] version of correlation id will be removed in 2.0
setCorrelationIdPolicy(DefaultMessagePropertiesConverter.CorrelationIdPolicy) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
Deprecated.
- the byte[] version of correlation id will be removed in 2.0
setCorrelationKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
If set to 'correlationId' (default) the correlationId property will be used; otherwise the supplied key will be used.
setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Determine whether or not the container should de-batch batched messages (true) or call the listener with the batch (false).
setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the number of retries after passive queue declaration fails.
setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the number of retries after passive queue declaration fails.
setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setDefaultConsumer(Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
setDefaultListenerMethod(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Specify the name of the default listener method to delegate to, for the case where no specific listener method has been determined.
setDefaultRequeueRejected(Boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Determines the default behavior when a message is rejected, for example because the listener threw an exception.
setDefaultTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Specify the default target ConnectionFactory, if any.
setDelegate(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Set a target object to delegate message listening to.
setDelegates(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
setDelegates(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setDestinationExchange(Exchange) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setDestinationQueue(Queue) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setDurable(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setDurable(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setEnableConfirms(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Set to true to enable publisher confirms.
setEncoding(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The encoding to use when inter-converting between byte arrays and Strings in message properties.
setEncoding(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
The encoding to use when inter-converting between byte arrays and Strings in message properties.
setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
Set the RabbitListenerEndpointRegistry that will hold the created endpoint and manage the lifecycle of the related listener container.
setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Set the RabbitListenerEndpointRegistry instance to use.
setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
setErrorRoutingKeyPrefix(String) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setExchange(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The name of the default exchange to use for send operations when none is specified.
setExchangeName(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setExchangeName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setExchangeType(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setExchangeType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set if a single consumer in the container will have exclusive use of the queues, preventing other consumers from receiving messages from the queue(s).
setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set to true for an exclusive consumer - if true, the concurrency must be 1.
setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set a ConditionalExceptionLogger for logging exclusive consumer failures.
setExecutor(Executor) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Provide an Executor for use by the Rabbit ConnectionFactory when creating connections.
setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set whether to expose the listener Rabbit Channel to a registered ChannelAwareMessageListener as well as to RabbitTemplate calls.
setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the interval between passive queue declaration attempts in milliseconds.
setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the interval between passive queue declaration attempts in milliseconds.
setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setGroup(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the group for the corresponding listener container.
setHandlerMethod(HandlerAdapter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
Set the HandlerAdapter to use to invoke the method processing an incoming Message.
setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
Set the AmqpHeaderMapper implementation to use to map the standard AMQP headers.
setHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setHost(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setId(String) - Method in class org.springframework.amqp.rabbit.support.CorrelationData
Set the correlation id.
setIdleEventInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
How often to publish idle container events.
setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
How often to emit ListenerContainerIdleEvents in milliseconds.
setIgnoreDeclarationExceptions(Boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setIncludeCallerData(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
If true, the caller data will be available in the target AMQP message.
setKeyStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store resource (e.g.
setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store pass phrase - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setKeyStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set a Resource pointing to the key store.
setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store type - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setLayout(Layout<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setLenientFallback(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Specify whether to apply a lenient fallback to the default ConnectionFactory if no specific ConnectionFactory could be found for the current lookup key.
setListenerId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setLocallyTransacted(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
True if the channel is locally transacted.
setLookupKeyQualifier(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set a qualifier that will prefix the connection factory lookup key; default none.
setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Set to true to enable the receipt of returned messages that cannot be delivered in the form of a AmqpMessageReturnedException.
setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setMandatoryPublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
setMaxConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Sets an upper limit to the number of consumers; defaults to 'concurrentConsumers'.
setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set the message converter for this template.
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the MessageConverter strategy for converting AMQP Messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set the converter that will convert incoming Rabbit messages to listener method arguments, and objects returned from listener methods back to Rabbit messages.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
Set the MessageHandlerMethodFactory to use to configure the message listener responsible to serve an endpoint detected by this processor.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Set the MessageHandlerMethodFactory to use to build the InvocableHandlerMethod responsible to manage the invocation of this endpoint.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Set the MessageHandlerMethodFactory to use to configure the message listener responsible to serve an endpoint detected by this processor.
setMessageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
Set the MessageListener to invoke when a message matching the endpoint is received.
setMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the message listener implementation to register.
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set the MessagePropertiesConverter for this template.
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the MessagePropertiesConverter for this listener container.
setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
setMethod(Method) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Set the method to invoke to process a message managed by this endpoint.
setMetricsCollector(MetricsCollector) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setMismatchedQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Prevent the container from starting if any of the queues defined in the context have mismatched arguments (TTL etc).
setMissingQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
If all of the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal (default true).
setNewMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
setNioParams(NioParams) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
 
setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setPassword(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setPassword(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setPhase(int) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setPhase(int) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setPhase(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Defaults to phase - 1000 so the factory is stopped in a very late phase, allowing other beans to use the connection to clean up.
setPhase(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Specify the phase in which this container should be started and stopped.
setPhysicalCloseRequired(boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Sets a ThreadLocal indicating the channel MUST be physically closed.
setPort(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setPort(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setPort(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setPort(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setPrefetchCount(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Tells the broker how many messages to send to each consumer in a single request.
setPriority(Integer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the priority of this endpoint.
setPublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setPublisherReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The name of the default queue to receive messages from when none is specified explicitly.
setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the name of the queue(s) to receive messages from.
setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the queue names to use.
setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setQueueOrTagToMethodName(Map<String, String>) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Set the mapping of queue name or consumer tag to method name.
setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the name of the queue(s) to receive messages from.
setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the queues to use.
setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setQuiesce(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Deprecated.
as redundant option in favor of BlockingQueueConsumer.basicCancel().
setRabbitAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the RabbitAdmin, used to declare any auto-delete queues, bindings etc when the container is started.
setRabbitOperations(RabbitOperations) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Set the RabbitTemplate for the gateway.
setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
Set the RabbitTemplate to use.
setReceiveConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
A SpEL Expression to evaluate against each receive queueName, if the provided RabbitAccessor.getConnectionFactory() is an instance of AbstractRoutingConnectionFactory.
setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Set the receive timeout - the future returned by the send and receive methods will be canceled when this timeout expires.
setReceiveTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Specify the receive timeout in milliseconds when using receive() methods (for sendAndReceive() methods, refer to replyTimeout.
setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
The time (in milliseconds) that a consumer should wait for data.
setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Specify the BackOff for interval between recovery attempts.
setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add a RecoveryCallback which is used for the retryTemplate.execute.
setRecoveryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Specify the interval between recovery attempts, in milliseconds.
setRecoveryListener(RecoveryListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set a RecoveryListener that will be added to each connection created.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the specified bean definition property with the reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition property corresponding to the specified attributeName with the reference to a bean identified by the value of that attribute if the attribute is defined in the given element.
setReplyAddress(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
An address for replies; if not provided, a temporary exclusive, auto-delete queue will be used for each reply, unless RabbitMQ supports 'amq.rabbitmq.reply-to' - see http://www.rabbitmq.com/direct-reply-to.html
setReplyPostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set a post processor to process the reply immediately before Channel#basicPublish().
setReplyQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Deprecated.
- use #setReplyAddress(String replyAddress)
setReplyTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Specify the timeout in milliseconds to be used when waiting for a reply Message when using one of the sendAndReceive methods.
setRequestedChannelMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setRequestedFrameMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setRequestedHeartBeat(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setRequestedHeartbeat(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setRequeueOnRollback(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Set to true to requeue a message on rollback; default true.
setResponseAddress(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set the default replyTo address to use when sending response messages.
setResponseExchange(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set the exchange to use when sending response messages.
setResponseRoutingKey(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set the routing key to use when sending response messages.
setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
When consuming multiple queues, set the interval between declaration attempts when only a subset of the queues were available (milliseconds).
setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
When consuming multiple queues, set the interval between declaration attempts when only a subset of the queues were available (milliseconds).
setRetryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add a RetryTemplate which will be used for all rabbit operations.
setReturnCallback(RabbitTemplate.ReturnCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The value of a default routing key to use for send operations when none is specified.
setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setSaslConfig(SaslConfig) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setSecureRandom(SecureRandom) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the secure random to use when initializing the SSLContext.
setSendConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
A SpEL Expression to evaluate against each request message, if the provided RabbitAccessor.getConnectionFactory() is an instance of AbstractRoutingConnectionFactory.
setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setSharedExecutor(ExecutorService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setShouldDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
The time to wait for workers in milliseconds after the container is stopped, and before the connection is forced closed.
setSkipServerCertificateValidation(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not Server Side certificate has to be validated or not.
setSocketConfigurator(SocketConfigurator) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setSocketFactory(SocketFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the algorithm to use; default TLSv1.1.
setSslPropertiesLocation(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
When RabbitConnectionFactoryBean.setUseSSL(boolean) is true, the SSL properties to use (optional).
setStartConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
If SimpleMessageListenerContainer.maxConcurrentConsumers is greater then SimpleMessageListenerContainer.concurrentConsumers, and SimpleMessageListenerContainer.maxConcurrentConsumers has not been reached, specifies the minimum time (milliseconds) between starting new consumers on demand.
setStopConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
If SimpleMessageListenerContainer.maxConcurrentConsumers is greater then SimpleMessageListenerContainer.concurrentConsumers, and the number of consumers exceeds SimpleMessageListenerContainer.concurrentConsumers, specifies the minimum time (milliseconds) between stopping idle consumers.
setTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the ConsumerTagStrategy to use when generating consumer tags.
setTargetConnectionFactories(Map<Object, ConnectionFactory>) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Specify the map of target ConnectionFactories, with the lookup key as key.
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Set the task scheduler to expire timed out futures.
setThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setTopologyRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set to true to enable amqp-client topology recovery.
setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setTrustStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store resource (e.g.
setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the trust store pass phrase - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setTrustStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set a Resource pointing to the trust store.
setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the trust store type - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setTxSize(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setTxSize(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Tells the container how many messages to process in a single transaction (if the channel is transactional).
setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
 
setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setupListenerContainer(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setupListenerContainer(MessageListenerContainer) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Setup the specified message listener container with the model defined by this endpoint.
setupMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setupMessageListener(Object) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
Setup the message listener to use.
setUpSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Override this method to take complete control over the SSL setup.
setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setUri(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setUri(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setUseNio(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not the factory should be configured to use Java NIO.
setUserIdExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set an expression to be evaluated to set the userId message property if it evaluates to a non-null value and the property is not already set in the message to be sent.
setUserIdExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set an expression to be evaluated to set the userId message property if it evaluates to a non-null value and the property is not already set in the message to be sent.
setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setUsername(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setUsername(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setUseSSL(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not the factory should be configured to use SSL.
setUseTemporaryReplyQueues(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
By default, when the broker supports it and no replyAddress is provided, send/receive methods will use Direct reply-to (https://www.rabbitmq.com/direct-reply-to.html).
setValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
setValue(Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the specified bean definition property with the value of the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Populates the bean definition property corresponding to the specified attributeName with the value of that attribute if it is defined in the given element.
setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
 
setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
sharedConnectionEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Always use a shared Rabbit Connection.
SharedConnectionNotInitializedException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.SharedConnectionNotInitializedException
Create a new SharedConnectionNotInitializedException.
shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.QueueParser
 
shouldRequeue(boolean, Throwable, Log) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Determine whether a message should be requeued; returns true if the throwable is a MessageRejectedWhileStoppingException or defaultRequeueRejected is true and there is not an AmqpRejectAndDontRequeueException in the cause chain.
shutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Stop the shared Connection, call AbstractMessageListenerContainer.doShutdown(), and close this container.
shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
SimpleBatchingStrategy - Class in org.springframework.amqp.rabbit.core.support
A simple batching strategy that supports only one exchange/routingKey; includes a batch size, a batched message size limit and a timeout.
SimpleBatchingStrategy(int, int, long) - Constructor for class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
 
SimpleConnection - Class in org.springframework.amqp.rabbit.connection
Simply a Connection.
SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
 
SimpleMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
 
SimpleMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Default constructor for convenient dependency injection via setters.
SimpleMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Create a listener container from the connection factory (mandatory).
SimpleMessageListenerContainer.ContainerDelegate - Interface in org.springframework.amqp.rabbit.listener
 
SimpleRabbitListenerContainerFactory - Class in org.springframework.amqp.rabbit.config
SimpleRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
SimpleRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.config
A RabbitListenerEndpoint simply providing the MessageListener to invoke to process an incoming message for this endpoint.
SimpleRabbitListenerEndpoint() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
 
SimpleResourceHolder - Class in org.springframework.amqp.rabbit.connection
Central helper that manages resources per thread to be used by resource management code.
SimpleRoutingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
An AbstractRoutingConnectionFactory implementation which gets a lookupKey for current ConnectionFactory from thread-bound resource by key of the instance of this ConnectionFactory.
SimpleRoutingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
 
start() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
start() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
start() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
start() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Start this container.
start() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
start() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
start() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
startSenders() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Submit the required number of senders into the pool.
stateful() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Create a builder for a stateful retry interceptor.
StatefulRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
Convenient factory bean for creating a stateful retry interceptor for use in a message listener container, giving you a large amount of control over the behaviour of a container when a listener fails.
StatefulRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
stateless() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Create a builder for a stateless retry interceptor.
StatelessRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
Convenient factory bean for creating a stateless retry interceptor for use in a message listener container, giving you a large amount of control over the behaviour of a container when a listener fails.
StatelessRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
 
stop() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
stop(Runnable) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
stop() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Stop the connection factory to prevent its connection from being used.
stop(Runnable) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
stop() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
stop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Stop this container.
stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
stop() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
stop() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
stop(long, TimeUnit, boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
stop() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 

T

toMessageProperties(AMQP.BasicProperties, Envelope, String) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
 
toMessageProperties(AMQP.BasicProperties, Envelope, String) - Method in interface org.springframework.amqp.rabbit.support.MessagePropertiesConverter
 
toMessagingMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
TopicExchangeParser - Class in org.springframework.amqp.rabbit.config
 
TopicExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.TopicExchangeParser
 
toString() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
toString() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
toString() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
toString() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
toString() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
toString() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ResultHolder
 
toString() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
toString() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
toString() - Method in class org.springframework.amqp.rabbit.support.CorrelationData
 
toString() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
 
toString() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
txCommit() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
txRollback() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
txSelect() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 

U

unbind(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Unbind a resource for the given key from the current thread.
unbindIfPossible(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Unbind a resource for the given key from the current thread.
unRegisterConsumerChannel() - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
See registerConsumerChannel.
updateClientConnectionProperties(AbstractConnectionFactory, String) - Static method in class org.springframework.amqp.rabbit.support.LogAppenderUtils
Parse the properties key:value[,key:value]... and add them to the connection factory client properties.
updateConnectionClientProperties(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Deprecated.
Subclasses can override this method to add properties to the connection client properties.
updateConnectionClientProperties(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Subclasses can override this method to add properties to the connection client properties.
useDirectReplyTo() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Override this method use some other criteria to decide whether or not to use direct reply-to (https://www.rabbitmq.com/direct-reply-to.html).

V

validateConfiguration() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Validate the configuration of this container.
validateConfiguration() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Avoid the possibility of not configuring the CachingConnectionFactory in sync with the number of concurrent consumers.
ValueExpression<V> - Class in org.springframework.amqp.rabbit.support
A very simple hardcoded implementation of the Expression interface that represents an immutable value.
ValueExpression(V) - Constructor for class org.springframework.amqp.rabbit.support.ValueExpression
 
valueOf(String) - Static method in enum org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter.CorrelationIdPolicy
Deprecated.
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter.CorrelationIdPolicy
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForConfirms() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirms(long) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie(long) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
wrapToListenerExecutionFailedExceptionIfNeeded(Exception, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 

X

X_EXCEPTION_MESSAGE - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
X_EXCEPTION_STACKTRACE - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
X_ORIGINAL_EXCHANGE - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
X_ORIGINAL_ROUTING_KEY - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
A B C D E F G H I L M N O P Q R S T U V W X 
Skip navigation links