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

A

abort() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
abort(int, String) - Method in class org.springframework.amqp.rabbit.connection.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
Root object for reply expression evaluation.
AbstractBuilder - Class in org.springframework.amqp.core
Base class for builders supporting arguments.
AbstractBuilder() - Constructor for class org.springframework.amqp.core.AbstractBuilder
 
AbstractCompressingPostProcessor - Class in org.springframework.amqp.support.postprocessor
Base class for post processors that compress the message body.
AbstractCompressingPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Construct a post processor that will include the MessageProperties.SPRING_AUTO_DECOMPRESS header set to 'true'.
AbstractCompressingPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Construct a post processor that will include (or not include) the MessageProperties.SPRING_AUTO_DECOMPRESS header.
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, with no publisher connection factory.
AbstractConnectionFactory.AddressShuffleMode - Enum in org.springframework.amqp.rabbit.connection
The mode used to shuffle the addresses.
AbstractDeclarable - Class in org.springframework.amqp.core
Base class for Declarable classes.
AbstractDeclarable() - Constructor for class org.springframework.amqp.core.AbstractDeclarable
 
AbstractDeclarable(Map<String, Object>) - Constructor for class org.springframework.amqp.core.AbstractDeclarable
Construct an instance with the supplied arguments, or an empty map if null.
AbstractDecompressingPostProcessor - Class in org.springframework.amqp.support.postprocessor
Base class for post processors that decompress the message body if the MessageProperties.SPRING_AUTO_DECOMPRESS header is true or to optionally always decompress if the content encoding matches AbstractDecompressingPostProcessor.getEncoding(), or starts with AbstractDecompressingPostProcessor.getEncoding() + ":", in which case the encoding following the colon becomes the final content encoding of the decompressed message.
AbstractDecompressingPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
Construct a post processor that will decompress the supported content encoding only if MessageProperties.SPRING_AUTO_DECOMPRESS header is present and true.
AbstractDecompressingPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
Construct a post processor that will decompress the supported content encoding if MessageProperties.SPRING_AUTO_DECOMPRESS header is present and true or if alwaysDecompress is true.
AbstractDeflaterPostProcessor - Class in org.springframework.amqp.support.postprocessor
Base class for post processors based on Deflater.
AbstractDeflaterPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
 
AbstractDeflaterPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
 
AbstractExchange - Class in org.springframework.amqp.core
Common properties that describe all exchange types.
AbstractExchange(String) - Constructor for class org.springframework.amqp.core.AbstractExchange
Construct a new durable, non-auto-delete Exchange with the provided name.
AbstractExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.AbstractExchange
Construct a new Exchange, given a name, durability flag, auto-delete flag.
AbstractExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.AbstractExchange
Construct a new Exchange, given a name, durability flag, and auto-delete flag, and arguments.
AbstractExchangeParser - Class in org.springframework.amqp.rabbit.config
 
AbstractExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
AbstractJackson2MessageConverter - Class in org.springframework.amqp.support.converter
Abstract Jackson2 message converter.
AbstractJackson2MessageConverter(ObjectMapper, MimeType, String...) - Constructor for class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Construct with the provided ObjectMapper instance.
AbstractJavaTypeMapper - Class in org.springframework.amqp.support.converter
Abstract type mapper.
AbstractJavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
AbstractMessageConverter - Class in org.springframework.amqp.support.converter
Convenient base class for MessageConverter implementations.
AbstractMessageConverter() - Constructor for class org.springframework.amqp.support.converter.AbstractMessageConverter
 
AbstractMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
 
AbstractMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
AbstractMessageListenerContainer.JavaLangErrorHandler - Interface in org.springframework.amqp.rabbit.listener
A handler for Error on the container thread(s).
AbstractMessageListenerContainer.SharedConnectionNotInitializedException - Exception in org.springframework.amqp.rabbit.listener
Exception that indicates that the initial setup of this container's shared Rabbit Connection failed.
AbstractMessageListenerContainer.WrappedTransactionException - Exception in org.springframework.amqp.rabbit.listener
A runtime exception to wrap a Throwable.
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
 
acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke Consumer.accept(Object) with the value if the condition is true.
acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the condition is true.
acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the value argument is not null or empty.
acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null.
acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the t2 argument is not null.
AcknowledgeMode - Enum in org.springframework.amqp.core
Acknowledgment modes supported by the listener container.
ActiveObjectCounter<T> - Class in org.springframework.amqp.rabbit.support
A mechanism to keep track of active objects.
ActiveObjectCounter() - Constructor for class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
actualInvokeListener(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the specified listener: either as standard MessageListener or (preferably) as SessionAwareMessageListener.
actualStart() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
 
add(T) - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
addAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add MessagePostProcessor that will be invoked immediately after a Channel#basicGet() and before any message conversion is performed.
addAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Add MessagePostProcessors that will be applied after message reception, before invoking the MessageListener.
addAllowedListPatterns(String...) - Static method in class org.springframework.amqp.core.Message
Add patterns to the allowed list of permissible package/class name patterns for deserialization in Message.toString().
addAllowedListPatterns(String...) - Method in class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
Add package/class patterns to the allowed list.
addAndStartConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Start up to delta consumers, limited by SimpleMessageListenerContainer.setMaxConcurrentConsumers(int).
addArgument(String, Object) - Method in class org.springframework.amqp.core.AbstractDeclarable
 
addArgument(String, Object) - Method in interface org.springframework.amqp.core.Declarable
Add an argument to the declarable.
addBeforePublishPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add MessagePostProcessor that will be invoked immediately before invoking Channel#basicPublish(), after all other processing, except creating the AMQP.BasicProperties from MessageProperties.
addBlockedListener(BlockedListener) - Method in interface org.springframework.amqp.rabbit.connection.Connection
Add a BlockedListener.
addBlockedListener(BlockedListener) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
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.connection.PublisherCallbackChannelImpl
 
addConfirmListener(ConfirmCallback, ConfirmCallback) - Method in class org.springframework.amqp.rabbit.connection.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
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
 
addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
 
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.
addDecompressor(String, MessagePostProcessor) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
Add a message post processor to the map of decompressing MessageProcessors.
addDelegate(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
addDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
addDelegate(String, MessageConverter) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
Add a delegate converter for the content type.
addDeliveryTag(Channel, long) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
addHeader(MessageProperties, String, Class<?>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
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.connection.PublisherCallbackChannel
addListener(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Add the listener and return the internal map of pending confirmations for that listener.
addListener(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add this template as a confirms listener for the provided channel.
addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Adds a pending confirmation to this channel's map.
addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
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.DirectMessageListenerContainer
 
addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
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.DirectMessageListenerContainer
 
addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Add queue(s) to this container's list of queues.
addRecoveryListenerIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
Add a listener if necessary so we can immediately close an autorecovered channel if necessary since the actual consumer will no longer exist.
Address - Class in org.springframework.amqp.core
Represents an address for publication of an AMQP message.
Address(String) - Constructor for class org.springframework.amqp.core.Address
Create an Address instance from a structured String with the form
 (exchange)/(routingKey)
Address(String, String) - Constructor for class org.springframework.amqp.core.Address
Create an Address given the exchange name and routing key.
ADDRESS - Static variable in class org.springframework.amqp.support.SendRetryContextAccessor
Key for the Address we tried to send to.
addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
addReturnListener(ReturnCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
addShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.connection.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.batch.BatchingStrategy
Add a message to the batch and optionally release the batch.
addToBatch(String, String, Message) - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
 
addTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
addTrustedPackages(String...) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
Add trusted packages.
adjustConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Adjust consumers depending on delta.
adjustLogLevels(String, List<Class<?>>, List<String>, Level) - Static method in class org.springframework.amqp.rabbit.junit.JUnitUtils
 
admins(Object...) - Method in class org.springframework.amqp.core.ExchangeBuilder
Admin instances, or admin bean names that should declare this exchange.
afterAll(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
afterAll(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
AfterCompletionFailedException - Exception in org.springframework.amqp.rabbit.connection
Represents a failure to commit or rollback when performing afterCompletion after the primary transaction completes.
AfterCompletionFailedException(int, Throwable) - Constructor for exception org.springframework.amqp.rabbit.connection.AfterCompletionFailedException
Construct an instance with the provided properties.
afterEach(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
afterEach(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
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.connection.RabbitConnectionFactoryBean
 
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 interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
 
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.
afterPropertiesSet() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
 
afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
 
afterSingletonsInstantiated() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
AllowedListDeserializingMessageConverter - Class in org.springframework.amqp.support.converter
MessageConverters that potentially use Java deserialization.
AllowedListDeserializingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
 
alternate(String) - Method in class org.springframework.amqp.core.ExchangeBuilder
 
AMQ_RABBITMQ_REPLY_TO - Static variable in class org.springframework.amqp.core.Address
Use this value in RabbitTemplate#setReplyAddress(String) to explicitly indicate that direct reply-to is to be used.
AmqpAdmin - Interface in org.springframework.amqp.core
Specifies a basic set of portable AMQP administrative operations for AMQP > 0.9.
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, Property[], AmqpAppender.AmqpManager, BlockingQueue<AmqpAppender.Event>) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Construct an instance with the provided properties.
AmqpAppender - Class in org.springframework.amqp.rabbit.logback
A Logback 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
Manager class for the appender.
AmqpAppender.Builder - Class in org.springframework.amqp.rabbit.log4j2
 
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.log4j2
Helper class to actually send LoggingEvents asynchronously.
AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.logback
Helper class to actually send LoggingEvents asynchronously.
AmqpApplicationContextClosedException - Exception in org.springframework.amqp
Thrown when the connection factory has been destroyed during context close; the factory can no longer open connections.
AmqpApplicationContextClosedException(String) - Constructor for exception org.springframework.amqp.AmqpApplicationContextClosedException
 
AmqpAuthenticationException - Exception in org.springframework.amqp
Runtime wrapper for an authentication exception.
AmqpAuthenticationException(Throwable) - Constructor for exception org.springframework.amqp.AmqpAuthenticationException
 
AmqpClientInterceptor - Class in org.springframework.amqp.remoting.client
MethodInterceptor for accessing RMI-style AMQP services.
AmqpClientInterceptor() - Constructor for class org.springframework.amqp.remoting.client.AmqpClientInterceptor
 
AmqpConnectException - Exception in org.springframework.amqp
RuntimeException wrapper for an ConnectException which can be commonly thrown from AMQP operations if the remote process dies or there is a network issue.
AmqpConnectException(Exception) - Constructor for exception org.springframework.amqp.AmqpConnectException
Construct an instance with the supplied message and cause.
AmqpConnectException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpConnectException
Construct an instance with the supplied message and cause.
AmqpEvent - Class in org.springframework.amqp.event
Base class for events.
AmqpEvent(Object) - Constructor for class org.springframework.amqp.event.AmqpEvent
 
AmqpException - Exception in org.springframework.amqp
Base RuntimeException for errors that occur when executing AMQP operations.
AmqpException(String) - Constructor for exception org.springframework.amqp.AmqpException
 
AmqpException(Throwable) - Constructor for exception org.springframework.amqp.AmqpException
 
AmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpException
 
AmqpHeaderMapper - Interface in org.springframework.amqp.support
Strategy interface for mapping messaging Message headers to an outbound MessageProperties (e.g.
AmqpHeaders - Class in org.springframework.amqp.support
Pre-defined names and prefixes to be used for setting and/or retrieving AMQP MessageProperties from/to Message Headers.
AmqpHeaders() - Constructor for class org.springframework.amqp.support.AmqpHeaders
 
AmqpIllegalStateException - Exception in org.springframework.amqp
Equivalent of an IllegalStateException but within the AmqpException hierarchy.
AmqpIllegalStateException(String) - Constructor for exception org.springframework.amqp.AmqpIllegalStateException
 
AmqpIllegalStateException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpIllegalStateException
 
AmqpInvokerServiceExporter - Class in org.springframework.amqp.remoting.service
This message listener exposes a plain java service via AMQP.
AmqpInvokerServiceExporter() - Constructor for class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
 
AmqpIOException - Exception in org.springframework.amqp
RuntimeException wrapper for an IOException which can be commonly thrown from AMQP operations.
AmqpIOException(IOException) - Constructor for exception org.springframework.amqp.AmqpIOException
Construct an instance with the provided cause.
AmqpIOException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpIOException
Construct an instance with the provided message and cause.
AmqpManager(LoggerContext, String) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
 
AmqpMessageHeaderAccessor - Class in org.springframework.amqp.support
A MessageHeaderAccessor implementation giving access to AMQP-specific headers.
AmqpMessageHeaderAccessor(Map<String, List<String>>) - Constructor for class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
AmqpMessageHeaderAccessor(Message<?>) - Constructor for class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
AmqpMessageReturnedException - Exception in org.springframework.amqp.core
Exception thrown if the request message cannot be delivered when the mandatory flag is set.
AmqpMessageReturnedException(String, Message, int, String, String, String) - Constructor for exception org.springframework.amqp.core.AmqpMessageReturnedException
Deprecated.
AmqpMessageReturnedException(String, ReturnedMessage) - Constructor for exception org.springframework.amqp.core.AmqpMessageReturnedException
 
AmqpNackReceivedException - Exception in org.springframework.amqp.rabbit.core
An exception thrown when a negative acknowledgement received after publishing a message.
AmqpNackReceivedException(String, Message) - Constructor for exception org.springframework.amqp.rabbit.core.AmqpNackReceivedException
Create an instance with the provided message and failed message.
AmqpProxyFactoryBean - Class in org.springframework.amqp.remoting.client
FactoryBean for AMQP proxies.
AmqpProxyFactoryBean() - Constructor for class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
 
AmqpRejectAndDontRequeueException - Exception in org.springframework.amqp
Exception for listener implementations used to indicate the basic.reject will be sent with requeue=false in order to enable features such as DLQ.
AmqpRejectAndDontRequeueException(String) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied argument.
AmqpRejectAndDontRequeueException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied argument.
AmqpRejectAndDontRequeueException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied arguments.
AmqpRejectAndDontRequeueException(String, boolean, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied arguments.
AmqpRemoteException - Exception in org.springframework.amqp
An exception that wraps an exception thrown by the server in a request/reply scenario.
AmqpRemoteException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRemoteException
 
AmqpReplyTimeoutException - Exception in org.springframework.amqp.core
Async reply timeout.
AmqpReplyTimeoutException(String, Message) - Constructor for exception org.springframework.amqp.core.AmqpReplyTimeoutException
 
AmqpResourceNotAvailableException - Exception in org.springframework.amqp
The AmqpException thrown when some resource can't be accessed.
AmqpResourceNotAvailableException(String) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
 
AmqpResourceNotAvailableException(Throwable) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
 
AmqpResourceNotAvailableException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
 
AmqpTemplate - Interface in org.springframework.amqp.core
Specifies a basic set of AMQP operations.
AmqpTimeoutException - Exception in org.springframework.amqp
Exception thrown when some time-bound operation fails to execute in the desired time.
AmqpTimeoutException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
 
AmqpTimeoutException(String) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
 
AmqpTimeoutException(Throwable) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
 
AmqpUnsupportedEncodingException - Exception in org.springframework.amqp
RuntimeException for unsupported encoding in an AMQP operation.
AmqpUnsupportedEncodingException(Throwable) - Constructor for exception org.springframework.amqp.AmqpUnsupportedEncodingException
 
and(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
 
andProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilder
Makes this builder's properties builder use a reference to properties.
AnonymousQueue - Class in org.springframework.amqp.core
Represents an anonymous, non-durable, exclusive, auto-delete queue.
AnonymousQueue() - Constructor for class org.springframework.amqp.core.AnonymousQueue
Construct a queue with a Base64-based name.
AnonymousQueue(Map<String, Object>) - Constructor for class org.springframework.amqp.core.AnonymousQueue
Construct a queue with a Base64-based name with the supplied arguments.
AnonymousQueue(NamingStrategy) - Constructor for class org.springframework.amqp.core.AnonymousQueue
Construct a queue with a name provided by the supplied naming strategy.
AnonymousQueue(NamingStrategy, Map<String, Object>) - Constructor for class org.springframework.amqp.core.AnonymousQueue
Construct a queue with a name provided by the supplied naming strategy with the supplied arguments.
answer(InvocationOnMock) - Method in class org.springframework.amqp.rabbit.test.mockito.LambdaAnswer
 
answer(InvocationOnMock) - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
 
APP_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
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.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.
apply(Statement, Description) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.amqp.rabbit.junit.LogLevelAdjuster
 
apply(Statement, Description) - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
 
apply(InvocationOnMock, T) - Method in interface org.springframework.amqp.rabbit.test.mockito.LambdaAnswer.ValueToReturn
 
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.
ArgumentBuilder - Class in org.springframework.amqp.rabbit.support
A builder for argument maps.
ArgumentBuilder() - Constructor for class org.springframework.amqp.rabbit.support.ArgumentBuilder
 
assertBeanFactory() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
AsyncAmqpTemplate - Interface in org.springframework.amqp.core
Classes implementing this interface can perform asynchronous send and receive operations.
asyncCompletableRpc(Method) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
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, AbstractMessageListenerContainer) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(RabbitTemplate, AbstractMessageListenerContainer, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(ConnectionFactory, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
AsyncRabbitTemplate(RabbitTemplate) - 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.connection.PublisherCallbackChannelImpl
 
autoDelete() - Method in class org.springframework.amqp.core.ExchangeBuilder
Set the auto delete flag.
autoDelete() - Method in class org.springframework.amqp.core.QueueBuilder
The final queue will auto delete.
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.support.ActiveObjectCounter
 
await(int) - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
Wait for the latch to count down.

B

backOffOptions(long, double, long) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the backoff options.
backOffPolicy(BackOffPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
Apply the back off policy.
Base64UrlNamingStrategy - Class in org.springframework.amqp.core
Generates names with the form <prefix><base64url> where 'prefix' is 'spring.gen-' by default (e.g.
Base64UrlNamingStrategy() - Constructor for class org.springframework.amqp.core.Base64UrlNamingStrategy
Construct an instance using the default prefix spring.gen-.
Base64UrlNamingStrategy(String) - Constructor for class org.springframework.amqp.core.Base64UrlNamingStrategy
Construct an instance using the supplied prefix.
BASE_PACKAGE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
BASIC_CLASS_ID_60 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP basic class id.
basicAck(long, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicCancel(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicCancel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicCancel(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicConsume(String, Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicConsume(String, DeliverCallback, CancelCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, DeliverCallback, CancelCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, String, DeliverCallback, CancelCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, Map<String, Object>, Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 3.3.x client.
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, CancelCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, CancelCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
basicGet(String, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicNack(long, boolean, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicPublish(String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicQos(int, int, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicQos(int, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 3.3.x client.
basicQos(int) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicRecover() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicRecover(boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicReject(long, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
BATCH_FORMAT_LENGTH_HEADER4 - Static variable in class org.springframework.amqp.core.MessageProperties
 
BATCH_SIZE - Static variable in class org.springframework.amqp.support.AmqpHeaders
The number of fragments in a batch message.
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
Create an instance with the supplied parameters.
BatchingRabbitTemplate(ConnectionFactory, BatchingStrategy, TaskScheduler) - Constructor for class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
Create an instance with the supplied parameters.
BatchingStrategy - Interface in org.springframework.amqp.rabbit.batch
Strategy for batching messages.
BatchMessageListener - Interface in org.springframework.amqp.core
Used to receive a batch of messages if the container supports it.
BatchMessagingMessageListenerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
A listener adapter for batch listeners.
BatchMessagingMessageListenerAdapter(Object, Method, boolean, RabbitListenerErrorHandler, BatchingStrategy) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.BatchMessagingMessageListenerAdapter
 
beforeAll(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
beforeEach(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
bind(Queue) - Static method in class org.springframework.amqp.core.BindingBuilder
 
bind(Exchange) - Static method in class org.springframework.amqp.core.BindingBuilder
 
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 - Class in org.springframework.amqp.core
Simple container collecting information to describe a binding.
Binding(String, Binding.DestinationType, String, String, Map<String, Object>) - Constructor for class org.springframework.amqp.core.Binding
 
Binding.DestinationType - Enum in org.springframework.amqp.core
The binding destination.
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
 
BindingBuilder - Class in org.springframework.amqp.core
Basic builder class to create bindings for a more fluent API style in code based configuration.
BindingBuilder.DestinationConfigurer - Class in org.springframework.amqp.core
General destination configurer.
BindingBuilder.DirectExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
Direct exchange routing key configurer.
BindingBuilder.GenericArgumentsConfigurer - Class in org.springframework.amqp.core
Generic argument configurer.
BindingBuilder.GenericExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
Generic exchange routing key configurer.
BindingBuilder.HeadersExchangeMapConfigurer - Class in org.springframework.amqp.core
Headers exchange configurer.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeKeysBindingCreator - Class in org.springframework.amqp.core
Headers exchange keys binding creator.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeMapBindingCreator - Class in org.springframework.amqp.core
Headers exchange map binding creator.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator - Class in org.springframework.amqp.core
Headers exchange single value binding creator.
BindingBuilder.TopicExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
Topic exchange routing key configurer.
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.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, boolean, Map<String, Object>, boolean, boolean, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BROKER_ADMIN_PW - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_ADMIN_URI - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_ADMIN_USER - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_HOSTNAME - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_PORT - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_PW - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_REQUIRED - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BROKER_USER - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
BrokerEvent - Class in org.springframework.amqp.rabbit.core
Represents a broker event generated by the Event Exchange Plugin (https://www.rabbitmq.com/event-exchange.html).
BrokerEvent(Object, MessageProperties) - Constructor for class org.springframework.amqp.rabbit.core.BrokerEvent
Create an instance with the provided source and properties.
BrokerEventListener - Class in org.springframework.amqp.rabbit.core
When the event-exchange-plugin is enabled (see https://www.rabbitmq.com/event-exchange.html), if an object of this type is declared as a bean, selected events will be published as BrokerEvents.
BrokerEventListener(ConnectionFactory, String...) - Constructor for class org.springframework.amqp.rabbit.core.BrokerEventListener
Construct an instance using the supplied connection factory and event keys.
BrokerEventListener(AbstractMessageListenerContainer, String...) - Constructor for class org.springframework.amqp.rabbit.core.BrokerEventListener
Construct an instance using the supplied listener container factory and event keys.
BrokerRunning - Class in org.springframework.amqp.rabbit.junit
A rule that prevents integration tests from failing if the Rabbit broker application is not running or not accessible.
BrokerRunningSupport - Class in org.springframework.amqp.rabbit.junit
A class that can be used to prevent integration tests from failing if the Rabbit broker application is not running or not accessible.
BrokerRunningSupport.BrokerNotAliveException - Exception in org.springframework.amqp.rabbit.junit
The RuntimeException thrown when broker is not available on the provided host port.
BrokerTestUtils - Class in org.springframework.amqp.rabbit.junit
Global convenience class for all integration tests, carrying constants and other utilities for broker set up.
build() - Method in class org.springframework.amqp.core.ExchangeBuilder
 
build() - Method in class org.springframework.amqp.core.MessageBuilder
 
build() - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
build() - Method in class org.springframework.amqp.core.MessagePropertiesBuilder
 
build() - Method in class org.springframework.amqp.core.QueueBuilder
Builds a final queue.
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
 
build() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
Builder() - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
buildInstance(String, Filter, Layout<? extends Serializable>, boolean, AmqpAppender.AmqpManager, BlockingQueue<AmqpAppender.Event>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
Subclasses can extends Builder, use same logic but need to modify class instance.
buildListenerArguments(Object, Channel, Message) - 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, Type) - 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, Type) - 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.
buildProperties() - Method in class org.springframework.amqp.core.MessageBuilderSupport
 

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) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a host name.
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, 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(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
The cache mode.
CachingConnectionFactory.ConfirmType - Enum in org.springframework.amqp.rabbit.connection
The type of publisher confirms to use.
call(Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Callable binding to the default ConnectionFactory and finally unbinding it.
call(String, Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Callable binding the given ConnectionFactory and finally unbinding it.
cancel(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
 
cancel(Channel, String) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
 
cancelled() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
canDebatch(MessageProperties) - Method in interface org.springframework.amqp.rabbit.batch.BatchingStrategy
Return true if this strategy can decode a batch of messages from a message body.
canDebatch(MessageProperties) - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
 
categories(String...) - Method in class org.springframework.amqp.rabbit.junit.LogLevelAdjuster
 
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.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
causeChainContainsARADRE(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Return true if there is already an AmqpRejectAndDontRequeueException present in the cause chain.
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.
CHANNEL - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
CHANNEL_PROTOCOL_CLASS_ID_20 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP Channel protocol class id.
ChannelAwareBatchMessageListener - Interface in org.springframework.amqp.rabbit.listener.api
Used to receive a batch of messages if the container supports it.
ChannelAwareMessageListener - Interface in org.springframework.amqp.rabbit.listener.api
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
A listener for new channel creation and destruction.
ChannelProxy - Interface in org.springframework.amqp.rabbit.connection
Subinterface of Channel to be implemented by Channel proxies.
checkAfterCompletion() - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
When using transaction synchronization, call this method after the transaction commits to verify that the RabbitMQ transaction committed.
checkAllowedList(Class<?>) - Method in class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
 
checkAllowedList(Class<?>, Set<String>) - Static method in class org.springframework.amqp.utils.SerializationUtils
Verify that the class is in the allowed list.
checkConnect() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
 
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.
checkMismatchedQueues() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
ClassMapper - Interface in org.springframework.amqp.support.converter
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
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.connection.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.
clearEnvironmentVariableOverrides() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Clear any environment variable overrides set in BrokerRunning.setEnvironmentVariableOverrides(Map).
clearEnvironmentVariableOverrides() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Clear any environment variable overrides set in BrokerRunningSupport.setEnvironmentVariableOverrides(Map).
clearPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Clear the physicalCloseRequired flag.
clearReturnListeners() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
clone() - Method in class org.springframework.amqp.core.Queue
 
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(int, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
close() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
closeAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
closeAndClear(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
closeChannel(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Close the given RabbitMQ Channel and ignore any thrown exception.
closeChannels(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
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
 
closeThreadChannel() - Method in interface org.springframework.amqp.rabbit.connection.Connection
Close any channel associated with the current thread.
closeThreadChannel() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Close the channel associated with this thread, if any.
ClosingRecoveryListener - Class in org.springframework.amqp.rabbit.connection
A RecoveryListener that closes the recovered channel, to avoid orphaned consumers.
CLUSTER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
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
A composite listener that invokes its delegages in turn.
CompositeConnectionListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
ConditionalExceptionLogger - Interface in org.springframework.amqp.support
For components that support customization of the logging of certain events, users can provide an implementation of this interface to modify the existing logging behavior.
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.
configure(C) - Method in interface org.springframework.amqp.rabbit.config.ContainerCustomizer
Configure the container.
configureAdminIfNeeded() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
configureKeyManagers() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
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
configureRabbitConnectionFactory(RabbitConnectionFactoryBean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
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.
configureTrustManagers() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
confirm(CorrelationData, boolean, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
Confirm(boolean, String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
 
confirm(CorrelationData, boolean, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
Confirmation callback.
confirmSelect() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
Connection - Interface in org.springframework.amqp.rabbit.connection
 
CONNECTION_PROTOCOL_CLASS_ID_10 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP Connection protocol class id.
ConnectionBlockedEvent - Class in org.springframework.amqp.rabbit.connection
The AmqpEvent emitted by the CachingConnectionFactory when its connections are blocked.
ConnectionBlockedEvent(Connection, String) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
 
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
 
ConnectionFactoryConfigurationUtils - Class in org.springframework.amqp.rabbit.connection
Utility methods for configuring connection factories.
ConnectionFactoryContextWrapper - Class in org.springframework.amqp.rabbit.connection
Helper class to handle ConnectionFactory context binding and unbinding when executing instructions.
ConnectionFactoryContextWrapper(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
 
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
A listener for connection creation and closing.
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.
ConnectionUnblockedEvent - Class in org.springframework.amqp.rabbit.connection
The AmqpEvent emitted by the CachingConnectionFactory when its connections are unblocked.
ConnectionUnblockedEvent(Connection) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
 
CONSUME_METHOD_ID_20 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP consume method.
ConsumeOkEvent - Class in org.springframework.amqp.rabbit.listener
An AmqpEvent emitted by the listener container when consumer is subscribed to the queue.
ConsumeOkEvent(Object, String, String) - Constructor for class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
Instantiate a ConsumeOkEvent based on the provided consumer, queue and consumer tag.
ConsumeOkNotReceivedException - Exception in org.springframework.amqp.rabbit.core
Thrown when a blocking receive operation is performed but the consumeOk was not received before the receive timeout.
ConsumeOkNotReceivedException(String) - Constructor for exception org.springframework.amqp.rabbit.core.ConsumeOkNotReceivedException
 
CONSUMER_QUEUE - Static variable in class org.springframework.amqp.support.AmqpHeaders
The queue from which the listener container consumer received the message.
CONSUMER_TAG - Static variable in class org.springframework.amqp.support.AmqpHeaders
The tag of the listener container consumer that received the message.
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.connection.PublisherCallbackChannelImpl
 
consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Called whenever a consumer is removed.
consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
consumers - Variable in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
 
consumersMonitor - Variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
ConsumerTagStrategy - Interface in org.springframework.amqp.support
A strategy interface to determine the consumer tag to be used when issuing a basicConsume operation.
containerAckMode(AcknowledgeMode) - Method in interface org.springframework.amqp.core.MessageListener
Called by the container to inform the listener of its acknowledgement mode.
containerAckMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
ContainerCustomizer<C extends AbstractMessageListenerContainer> - Interface in org.springframework.amqp.rabbit.config
Called by the container factory after the container is created and configured.
ContainerUtils - Class in org.springframework.amqp.rabbit.listener.support
Utility methods for listener containers.
containsChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
CONTENT_ENCODING - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
CONTENT_LENGTH - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
CONTENT_TYPE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
CONTENT_TYPE_BYTES - Static variable in class org.springframework.amqp.core.MessageProperties
 
CONTENT_TYPE_CONVERTER_WINS - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
CONTENT_TYPE_JSON - Static variable in class org.springframework.amqp.core.MessageProperties
 
CONTENT_TYPE_JSON_ALT - Static variable in class org.springframework.amqp.core.MessageProperties
 
CONTENT_TYPE_SERIALIZED_OBJECT - Static variable in class org.springframework.amqp.core.MessageProperties
 
CONTENT_TYPE_TEXT_PLAIN - Static variable in class org.springframework.amqp.core.MessageProperties
 
CONTENT_TYPE_XML - Static variable in class org.springframework.amqp.core.MessageProperties
 
ContentTypeDelegatingMessageConverter - Class in org.springframework.amqp.support.converter
A composite MessageConverter that delegates to an actual MessageConverter based on the contentType header.
ContentTypeDelegatingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
Constructs an instance using a default SimpleMessageConverter.
ContentTypeDelegatingMessageConverter(MessageConverter) - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
Constructs an instance using a the supplied default converter.
convert(Object, Type, MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Convert to a message, with reply content type based on settings.
convert(Message, Type) - Method in class org.springframework.amqp.support.converter.ProjectingMessageConverter
 
convertAmqpException(RuntimeException) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAmqpMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a default exchange with a default routing key.
convertAndSend(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a default exchange with a specific routing key.
convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a specific exchange with a specific routing key.
convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a default exchange with a default routing key.
convertAndSend(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a default exchange with a specific routing key.
convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Convert a Java object to an Amqp Message and send it to a specific exchange with a specific routing key.
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(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a default exchange with a specific routing key.
convertAndSend(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a specific exchange with a specific routing key.
convertAndSend(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a default exchange with a default routing key.
convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a default exchange with a specific routing key.
convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a specific exchange with a specific routing key.
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(Object, MessagePostProcessor, CorrelationData) - 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 interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(String, String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceive(Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the default routing key.
convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the provided routing key.
convertSendAndReceive(String, String, Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key.
convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
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 interface org.springframework.amqp.core.AsyncAmqpTemplate
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 interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key after invoking the MessagePostProcessor.
convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
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, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
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
 
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the default routing key.
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the provided routing key.
convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key.
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the default routing key after invoking the MessagePostProcessor.
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the default exchange with the provided routing key after invoking the MessagePostProcessor.
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key after invoking the MessagePostProcessor.
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - 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.
copyHeaders(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
copyHeadersIfAbsent(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessagePropertiesBuilder
 
Correlation - Interface in org.springframework.amqp.core
A marker interface for data used to correlate information about sent messages.
CORRELATION_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
correlationConvertAndSend(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Convert a Java object to an Amqp Message and send it to a default exchange with a default routing key.
correlationConvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
CorrelationData - Class in org.springframework.amqp.rabbit.connection
Base class for correlating publisher confirms to sent messages.
CorrelationData() - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
Construct an instance with a null Id.
CorrelationData(String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
Construct an instance with the supplied id.
CorrelationData.Confirm - Class in org.springframework.amqp.rabbit.connection
Represents a publisher confirmation.
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.
countDown() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
Count down the returned message latch; call after the listener has been called.
counter - Variable in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
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(Channel, ExecutorService) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelFactory
Create a PublisherCallbackChannel instance based on the provided delegate and executor.
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(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
Create a connection with this connection factory and/or its publisher factory.
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.PooledChannelConnectionFactory
 
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.
createConnection() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
 
createConnectionFactory(String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
Create a dedicated connection factory for the address.
createConsumerTag(String) - Method in interface org.springframework.amqp.support.ConsumerTagStrategy
Create the consumer tag, optionally based on the queue name that the consumer will listen to.
createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Create an empty container instance.
createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
 
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.
createEventQueue() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Subclasses can override this method to inject a custom queue implementation.
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.config.ListenerContainerFactoryBean
 
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() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
Create a MessageListenerContainer with no MessageListener or queues; the listener must be added later before the container is started.
createListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Create and start a new MessageListenerContainer using the specified factory.
createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
Crate a message from the payload object and message properties provided.
createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
Crate a message from the payload object and message properties provided.
createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Marshals the given object to a Message.
createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
Creates an AMQP Message from the provided Object.
createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Creates an AMQP Message from the provided Object.
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.
createObjectInputStream(InputStream, String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Create an ObjectInputStream for the given InputStream and codebase.
createRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
Create the ConnectionFactory.
createRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
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.
CustomExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a custom exchange.
CustomExchange(String, String) - Constructor for class org.springframework.amqp.core.CustomExchange
 
CustomExchange(String, String, boolean, boolean) - Constructor for class org.springframework.amqp.core.CustomExchange
 
CustomExchange(String, String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.CustomExchange
 

D

deactivate() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
deadLetterExchange(String) - Method in class org.springframework.amqp.core.QueueBuilder
Set the dead-letter exchange to which to route expired or rejected messages.
deadLetterRoutingKey(String) - Method in class org.springframework.amqp.core.QueueBuilder
Set the routing key to use when routing expired or rejected messages to the dead-letter exchange.
deBatch(Message, Consumer<Message>) - Method in interface org.springframework.amqp.rabbit.batch.BatchingStrategy
Decode a message into fragments.
deBatch(Message, Consumer<Message>) - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
debatch(Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
Declarable - Interface in org.springframework.amqp.core
Classes implementing this interface can be auto-declared with the broker during context initialization by an AmqpAdmin.
DeclarableCustomizer - Interface in org.springframework.amqp.core
Beans of this type are invoked by the AmqpAdmin before declaring the Declarable, allowing customization thereof.
Declarables - Class in org.springframework.amqp.core
A collection of Declarable objects; used to declare multiple objects on the broker using a single bean declaration for the collection.
Declarables(Declarable...) - Constructor for class org.springframework.amqp.core.Declarables
 
Declarables(Collection<Declarable>) - Constructor for class org.springframework.amqp.core.Declarables
 
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
 
DECLARE_METHOD_ID_10 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP declare method.
declareBinding(Binding) - Method in interface org.springframework.amqp.core.AmqpAdmin
Declare a binding of a queue to an exchange.
declareBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
declareExchange(Exchange) - Method in interface org.springframework.amqp.core.AmqpAdmin
Declare an exchange.
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() - Method in interface org.springframework.amqp.core.AmqpAdmin
Declare a queue whose name is automatically named.
declareQueue(Queue) - Method in interface org.springframework.amqp.core.AmqpAdmin
Declare the given queue.
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 - Static variable in class org.springframework.amqp.core.Base64UrlNamingStrategy
The default instance - using spring.gen- as the prefix.
DEFAULT - Static variable in class org.springframework.amqp.core.DirectExchange
The default exchange.
DEFAULT - Static variable in class org.springframework.amqp.core.UUIDNamingStrategy
The default instance.
DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
The charset used when converting String to/from byte[].
DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.SerializerMessageConverter
 
DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.SimpleMessageConverter
 
DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.DefaultClassMapper
 
DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
DEFAULT_CONTENT_TYPE - Static variable in class org.springframework.amqp.core.MessageProperties
 
DEFAULT_DEBATCHING_ENABLED - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
DEFAULT_DELIVERY_MODE - Static variable in class org.springframework.amqp.core.MessageProperties
 
DEFAULT_EXCHANGE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
The default exchange name.
DEFAULT_FRAME_MAX_HEADROOM - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
DEFAULT_PORT - Static variable in class org.springframework.amqp.rabbit.junit.BrokerTestUtils
 
DEFAULT_PREFETCH_COUNT - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
DEFAULT_PRIORITY - Static variable in class org.springframework.amqp.core.MessageProperties
 
DEFAULT_QUEUE_NAME - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
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.AbstractMessageListenerContainer
The default recovery interval: 5000 ms = 5 seconds.
DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
DefaultClassMapper - Class in org.springframework.amqp.support.converter
Maps to/from JSON using type information in the MessageProperties; the default name of the message property containing the type is "__TypeId__".
DefaultClassMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultClassMapper
 
DefaultExceptionStrategy() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
 
DefaultJackson2JavaTypeMapper - Class in org.springframework.amqp.support.converter
Jackson 2 type mapper.
DefaultJackson2JavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
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.
DeflaterPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a DeflaterOutputStream to compress the message body.
DeflaterPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
 
DeflaterPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
 
DELAY - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
delayed() - Method in class org.springframework.amqp.core.ExchangeBuilder
Set the delayed flag.
delegate() - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnsCallback
Deprecated.
- will be removed with RabbitTemplate.ReturnCallback.
DelegatingDecompressingPostProcessor - Class in org.springframework.amqp.support.postprocessor
A MessagePostProcessor that delegates to one of its MessagePostProcessors depending on the content encoding.
DelegatingDecompressingPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
Construct an instance with the default decompressors (gzip, zip, deflate) with the alwaysDecompress flag set to true.
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.
DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Construct an instance with the supplied handlers for the bean.
DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext, Validator) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Construct an instance with the supplied handlers for the bean.
deleteExchange(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Delete an exchange.
deleteExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteExchanges(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Delete arbitrary exchanges from the broker.
deleteExchanges(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Delete arbitrary exchanges from the broker.
deleteQueue(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Delete a queue, without regard for whether it is in use or has messages on it.
deleteQueue(String, boolean, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
Delete a queue.
deleteQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteQueue(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Delete arbitrary queues from the broker.
deleteQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Delete arbitrary queues from the broker.
Delivery - Class in org.springframework.amqp.rabbit.support
Encapsulates an arbitrary message - simple "bean" holder structure.
Delivery(String, Envelope, AMQP.BasicProperties, byte[], String) - Constructor for class org.springframework.amqp.rabbit.support.Delivery
 
DELIVERY_MODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
DELIVERY_TAG - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
deliveryLimit(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the delivery limit; only applies to quorum queues.
deserialize(byte[]) - Static method in class org.springframework.amqp.utils.SerializationUtils
Deserialize the bytes.
deserialize(ObjectInputStream) - Static method in class org.springframework.amqp.utils.SerializationUtils
Deserialize the stream.
deserialize(InputStream, Set<String>, ClassLoader) - Static method in class org.springframework.amqp.utils.SerializationUtils
Deserialize the stream.
destination - Variable in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
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.connection.PooledChannelConnectionFactory
 
destroy() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
 
destroy() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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.
DIRECT - Static variable in class org.springframework.amqp.core.ExchangeTypes
Direct exchange.
DirectExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a direct exchange.
DirectExchange(String) - Constructor for class org.springframework.amqp.core.DirectExchange
 
DirectExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.DirectExchange
 
DirectExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.DirectExchange
 
directExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
Return a DirectExchange builder.
DirectExchangeParser - Class in org.springframework.amqp.rabbit.config
 
DirectExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.DirectExchangeParser
 
DirectMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
The SimpleMessageListenerContainer is not so simple.
DirectMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Create an instance; RabbitAccessor.setConnectionFactory(ConnectionFactory) must be called before starting.
DirectMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Create an instance with the provided connection factory.
DirectRabbitListenerContainerFactory - Class in org.springframework.amqp.rabbit.config
DirectRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
 
DirectReplyToMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
Listener container for Direct ReplyTo only listens to the pseudo queue Address.AMQ_RABBITMQ_REPLY_TO.
DirectReplyToMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
DirectReplyToMessageListenerContainer.ChannelHolder - Class in org.springframework.amqp.rabbit.listener
Holder for a channel; contains a consumer epoch used to prevent inappropriate release of the consumer after it has been allocated for reuse.
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
 
doHandleResult(InvocationResult, Message, Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
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.DirectMessageListenerContainer
 
doInitialize() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
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.
doInRabbit(RabbitOperations) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations.OperationsCallback
Execute any number of operations using a dedicated Channel as long as those operations are performed on the template argument and on the calling thread.
doInvokeListener(ChannelAwareMessageListener, Channel, Object) - 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, Object) - 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
 
doPublish(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
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.
doRedeclareElementsIfNecessary() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
 
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.
doSend(AmqpAppender.Event, LogEvent, MessageProperties) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
doSend(String, String, Message) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
Send the message.
doSend(String, String, Message) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
 
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
 
doSendAndReceiveWithFixed(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
doSendAndReceiveWithTemporary(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
doSetPossibleAuthenticationFailureFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
doSetPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
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.DirectMessageListenerContainer
 
doShutdown() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
doStart() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
doStart() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Perform additional start actions.
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.DirectMessageListenerContainer
 
doStart() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
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.core.BatchingRabbitTemplate
 
doStop() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Perform additional stop actions.
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.DirectMessageListenerContainer
 
doSuspend(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
durable(boolean) - Method in class org.springframework.amqp.core.ExchangeBuilder
Set the durable flag.
durable() - Static method in class org.springframework.amqp.core.QueueBuilder
Creates a builder for a durable queue with a generated unique name - spring.gen-<random>.
durable(String) - Static method in class org.springframework.amqp.core.QueueBuilder
Creates a builder for a durable queue.

E

enableAfterCompletionFailureCapture(boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
Call this method to enable capturing AfterCompletionFailedExceptions when using transaction synchronization.
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.core.Address
 
equals(Object) - Method in class org.springframework.amqp.core.Message
 
equals(Object) - Method in class org.springframework.amqp.core.MessageProperties
 
equals(Object) - Method in class org.springframework.amqp.core.QueueInformation
 
equals(Object) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
errorExchangeName - Variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
errorRoutingKey - Variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
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.
errorTemplate - Variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTestCondition
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
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.log4j2.AmqpAppender.EventSender
 
EventSender() - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender.EventSender
 
exchange - Variable in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
Exchange - Interface in org.springframework.amqp.core
Interface for all exchanges.
Exchange - Annotation Type in org.springframework.amqp.rabbit.annotation
An exchange to which to bind a RabbitListener queue.
EXCHANGE_CLASS_ID_40 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP exchange class id.
exchangeBind(String, String, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeBindNoWait(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
ExchangeBuilder - Class in org.springframework.amqp.core
Builder providing a fluent API for building Exchanges.
ExchangeBuilder(String, String) - Constructor for class org.springframework.amqp.core.ExchangeBuilder
Construct an instance of the appropriate type.
exchangeDeclare(String, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclareNoWait(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclareNoWait(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDelete(String, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDelete(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeleteNoWait(String, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
ExchangeTypes - Class in org.springframework.amqp.core
Constants for the standard Exchange type names.
ExchangeTypes() - Constructor for class org.springframework.amqp.core.ExchangeTypes
 
exchangeUnbind(String, String, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeUnbindNoWait(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exclusive() - Method in class org.springframework.amqp.core.QueueBuilder
The final queue will be exclusive.
execute(ChannelCallback<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Execute the callback with a channel and reliably close the channel afterwards.
execute(ChannelCallback<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
executeListener(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Execute the specified listener, committing or rolling back the transaction afterwards (if necessary).
exist() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeKeysBindingCreator
 
exists() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator
 
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.
EXPIRATION - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
expire(PublisherCallbackChannel.Listener, long) - Method in interface org.springframework.amqp.rabbit.connection.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.connection.PublisherCallbackChannelImpl
 
expires(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the time that the queue can remain unused before being deleted.
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.
extractPayload(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
 
extractPayload(Message) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
Extract the payload of the specified Message.

F

factory() - Static method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
FALSE - Static variable in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
FANOUT - Static variable in class org.springframework.amqp.core.ExchangeTypes
Fanout exchange.
fanoutExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
Return a FanoutExchange builder.
FanoutExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a fanout exchange.
FanoutExchange(String) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchangeParser - Class in org.springframework.amqp.rabbit.config
 
FanoutExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
fatal() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
fatal() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
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 with an irrecoverable problem.
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
 
findIdleConsumer() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
When adjusting down, return a consumer that can be canceled.
findIdleConsumer() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
flush() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
Flush any partial in-progress batches.
frameMaxHeadroom(int) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
Set the amount by which the negotiated frame_max is to be reduced when considering truncating the stack trace header.
fromClass(Class<?>, MessageProperties) - Method in interface org.springframework.amqp.support.converter.ClassMapper
 
fromClass(Class<?>, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
 
fromClass(Class<?>, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
fromClonedMessage(Message) - Static method in class org.springframework.amqp.core.MessageBuilder
The final message will have a copy of the message body, the MessageProperties will be cloned (top level only).
fromClonedProperties(MessageProperties) - Static method in class org.springframework.amqp.core.MessagePropertiesBuilder
Performs a shallow copy of the properties for the initial value.
fromHeaders(MessageHeaders, MessageProperties) - Method in class org.springframework.amqp.support.SimpleAmqpHeaderMapper
 
fromInferredTypeHeader(MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
fromInt(int) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
 
fromJavaType(JavaType, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
fromJavaType(JavaType, MessageProperties) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
Set the message properties according to the type.
fromMessage(Message) - Static method in class org.springframework.amqp.core.MessageBuilder
The final message body will be a direct reference to the message body, the MessageProperties will be a shallow copy.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
fromMessage(Message, Object) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
A variant of MessageConverter.fromMessage(Message) which takes an extra conversion context as an argument.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Unmarshals the given Message into an object.
fromMessage(Message) - Method in interface org.springframework.amqp.support.converter.MessageConverter
Convert from a Message to a Java object.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
Converts from a AMQP Message to an Object.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Converts from a AMQP Message to an Object.
fromMessage(Message, Object) - Method in interface org.springframework.amqp.support.converter.SmartMessageConverter
A variant of MessageConverter.fromMessage(Message) which takes an extra conversion context as an argument.
fromMessageProperties(MessageProperties, String) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
 
fromMessageProperties(MessageProperties, String) - Method in interface org.springframework.amqp.rabbit.support.MessagePropertiesConverter
 
fromProperties(MessageProperties) - Static method in class org.springframework.amqp.core.MessagePropertiesBuilder
Initializes the builder with the supplied properties; the same object will be returned by MessagePropertiesBuilder.build().

G

generateId() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Generate the connection id for the connection used by the rule's connection factory.
generateId() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Generate the connection id for the connection used by the rule's connection factory.
generateName() - Method in class org.springframework.amqp.core.Base64UrlNamingStrategy
 
generateName() - Method in interface org.springframework.amqp.core.NamingStrategy
 
generateName() - Method in class org.springframework.amqp.core.UUIDNamingStrategy
 
GenericArgumentsConfigurer(BindingBuilder.GenericExchangeRoutingKeyConfigurer, String) - Constructor for class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
 
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.
get() - Method in class org.springframework.amqp.utils.MapBuilder
 
getAckMode() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getAckMode() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Override the container factory's AcknowledgeMode.
getAcknowledgeMode() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getActiveConsumerCount() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
getActualName() - Method in class org.springframework.amqp.core.Queue
Return the name provided to the constructor or the broker-generated name if that name is an empty String.
getAddress() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getAddress(RetryContext) - Static method in class org.springframework.amqp.support.SendRetryContextAccessor
Retrieve the Address from the context.
getAddresses() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getAdminPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the admin password.
getAdminPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the admin password.
getAdminUri() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the admin uri.
getAdminUri() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the admin uri.
getAdminUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the admin user.
getAdminUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the admin user.
getAdviceChain() - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
getAdviceChain() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getAfterReceivePostProcessors() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return configured after receive MessagePostProcessors or null.
getAfterReceivePostProcessors() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getAmqpAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getAmqpMessageConverter() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
getAmqpTemplate() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
 
getAmqpTemplate() - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
 
getAppId() - Method in class org.springframework.amqp.core.MessageProperties
 
getAppId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getApplicationContext() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getApplicationContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getApplicationEventPublisher() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getApplicationId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getArguments() - Method in class org.springframework.amqp.core.AbstractBuilder
 
getArguments() - Method in class org.springframework.amqp.core.AbstractDeclarable
 
getArguments() - Method in interface org.springframework.amqp.core.Exchange
A map of arguments used to declare the exchange.
getArguments() - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
 
getAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getAutoStartup() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Override of the default autoStartup property.
getBackOffExecution() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
getBatchingStrategy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getBatchingStrategy() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Get the bean from the handler method.
getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
 
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.connection.AbstractConnectionFactory
Return a bean name of the component or null if not a bean.
getBeanName() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getBeanName() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getBeanResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getBindingsFailedException() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
Return any exception thrown when attempting to bind the queue to the event exchange.
getBody() - Method in class org.springframework.amqp.core.Message
 
getBody() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the message body.
getBrokerRunning() - Static method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
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.connection.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
 
getChannel() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer.ChannelHolder
 
getChannelCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
getChannelHolder() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
Get the channel holder associated with a direct reply-to consumer; contains a consumer epoch to prevent inappropriate releases.
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.connection.PublisherCallbackChannelImpl
 
getChannelsExecutor() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Determine the executor service used for target channels.
getCharset() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
The name of the header that contains the type id.
getClassLoader() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
getClassLoader() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
getClassMapper() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
getCloseReason() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getCloseTimeout() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getClusterId() - Method in class org.springframework.amqp.core.MessageProperties
 
getClusterId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getCompressorStream(OutputStream) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Get the stream.
getCompressorStream(OutputStream) - Method in class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
 
getCompressorStream(OutputStream) - Method in class org.springframework.amqp.support.postprocessor.GZipPostProcessor
 
getCompressorStream(OutputStream) - Method in class org.springframework.amqp.support.postprocessor.ZipPostProcessor
 
getConcurrency() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
The concurrency of this endpoint; Not used by this abstract class; used by subclasses to set the concurrency appropriate for the container type.
getConcurrency() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
 
getConfirm() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
When confirms are enabled contains a ListenableFuture for the confirmation.
getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
 
getConnection(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Connection from the given RabbitResourceHolder.
getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
 
getConnection() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
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
 
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 interface org.springframework.amqp.rabbit.core.RabbitOperations
Return the connection factory for this operations.
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Get the connection factory used by this rule.
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Get the connection factory used by this rule.
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.
getConnectionNameStrategy() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getConsumeDelay() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Get the consumeDelay - a time to wait before consuming in ms.
getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
 
getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
 
getConsumerArguments() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the consumer arguments.
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.
getConsumerCount() - Method in class org.springframework.amqp.core.QueueInformation
 
getConsumerEpoch() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer.ChannelHolder
 
getConsumerQueue() - Method in class org.springframework.amqp.core.MessageProperties
 
getConsumerQueue() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getConsumerTag() - Method in class org.springframework.amqp.core.MessageProperties
 
getConsumerTag() - Method in class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
Obtain the consumer tag assigned to the consumer.
getConsumerTag() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the consumer tag.
getConsumerTag() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getConsumerTags() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
getConsumerTagStrategy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the consumer tag strategy to use.
getContentClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
getContentEncoding() - Method in class org.springframework.amqp.core.MessageProperties
 
getContentEncoding() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getContentEncoding() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getContentLength() - Method in class org.springframework.amqp.core.MessageProperties
 
getContentLength() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getContentType() - Method in class org.springframework.amqp.core.MessageProperties
 
getContentType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getContentType() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getContextStopped() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getConverterForContentType(String) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
 
getCorrelationData() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
The correlation data supplied by the client when sending the message corresponding to this confirmation.
getCorrelationId() - Method in class org.springframework.amqp.core.MessageProperties
Get the correlation id.
getCorrelationId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getCount() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
getCustomMethodArgumentResolvers() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Return the list of HandlerMethodArgumentResolver.
getDeclarable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
getDeclarables() - Method in class org.springframework.amqp.core.Declarables
 
getDeclarablesByType(Class<T>) - Method in class org.springframework.amqp.core.Declarables
Return the elements that are instances of the provided class.
getDeclaringAdmins() - Method in class org.springframework.amqp.core.AbstractDeclarable
 
getDeclaringAdmins() - Method in interface org.springframework.amqp.core.Declarable
The collection of AmqpAdmins that should declare this object; if empty, all admins should declare.
getDecompressorStream(InputStream) - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
Get the stream.
getDecompressorStream(InputStream) - Method in class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
 
getDecompressorStream(InputStream) - Method in class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
 
getDecompressorStream(InputStream) - Method in class org.springframework.amqp.support.postprocessor.UnzipPostProcessor
 
getDefaultCharset() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
getDefaultConsumer() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getDefaultHostName() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getDefaultListenerMethod() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
 
getDelay() - Method in class org.springframework.amqp.core.MessageProperties
The x-delay header (outbound).
getDelegate() - Method in interface org.springframework.amqp.rabbit.connection.Connection
Return the underlying RabbitMQ connection.
getDelegate() - Method in interface org.springframework.amqp.rabbit.connection.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.connection.PublisherCallbackChannelImpl
 
getDelegate() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
getDelegate() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
 
getDelegate(String) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
Get the actual listener object (not the spy).
getDelegates() - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
 
getDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
 
getDeliveryMode() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getDeliveryMode() - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
getDeliveryMode() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getDeliveryTag() - Method in class org.springframework.amqp.core.MessageProperties
 
getDeliveryTag() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getDestination() - Method in class org.springframework.amqp.core.Binding
 
getDestinationType() - Method in class org.springframework.amqp.core.Binding
 
getEncoder() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getEncoding() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The encoding used when converting between byte arrays and Strings in message properties.
getEncoding() - 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.
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Get the encoding.
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
Get the encoding.
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
 
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
 
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.GZipPostProcessor
 
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
 
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.UnzipPostProcessor
 
getEncoding() - Method in class org.springframework.amqp.support.postprocessor.ZipPostProcessor
 
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.
getErrorRoutingKeyPrefix() - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
getEvent() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
getEvent() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
getEventProperties() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
Properties of the event MessageProperties.getHeaders().
getEventType() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
getExceptions() - Method in class org.springframework.amqp.rabbit.test.mockito.LambdaAnswer
Return the exceptions thrown, if any.
getExceptions() - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
Return the exceptions thrown.
getExceptionStrategy() - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Return the exception strategy.
getExchange() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getExchange() - Method in class org.springframework.amqp.core.Binding
 
getExchange() - Method in class org.springframework.amqp.core.ReturnedMessage
Get the exchange.
getExchange() - Method in class org.springframework.amqp.rabbit.batch.MessageBatch
 
getExchange() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getExchangeName() - Method in class org.springframework.amqp.core.Address
 
getExchangeName() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getExchangeType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getExclusiveConsumerExceptionLogger() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getExecutorService() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getExpiration() - Method in class org.springframework.amqp.core.MessageProperties
 
getExpiration() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getExpressionString() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getFailedDeclarationRetryInterval() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getFailedMessage() - Method in exception org.springframework.amqp.rabbit.core.AmqpNackReceivedException
Return the failed message.
getFailedMessage() - Method in exception org.springframework.amqp.rabbit.support.ListenerExecutionFailedException
 
getFailedMessages() - Method in exception org.springframework.amqp.rabbit.support.ListenerExecutionFailedException
 
getFuture() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Return a future to check the success/failure of the publish operation.
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
 
getHeader(String) - Method in class org.springframework.amqp.core.MessageProperties
Typed getter for a header.
getHeaderMapper() - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
 
getHeaders() - Method in class org.springframework.amqp.core.MessageProperties
 
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.logback.AmqpAppender
 
getHostName() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the port.
getHostName() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the port.
getId() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Return the id.
getId() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getId() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
 
getIdClassMapping() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
getIdleEventInterval() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getIdleTime() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
How long the container has been idle.
getInferredArgumentType() - Method in class org.springframework.amqp.core.MessageProperties
The inferred target argument type when using a method-level @RabbitListener.
getInferredType(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
getInferredType(MessageProperties) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
Return the inferred type, if the type precedence is inferred and the header is present.
getInvocationResultFor(Object, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
getInvocationResultFor(Object, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Build an InvocationResult for the result and inbound payload.
getJavaLangErrorHandler() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getJavaTypeMapper() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
getKey(Message) - Method in interface org.springframework.amqp.rabbit.retry.MessageKeyGenerator
Generate a unique key for the message that is repeatable on redelivery.
getKeyClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
getKeyStore() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStore() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getKeyStoreAlgorithm() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStorePassphrase() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStorePassphrase() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getKeyStoreResource() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getKeyStoreType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
getKeyStoreType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getLambdaAnswerFor(String, boolean, LambdaAnswer.ValueToReturn<T>) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
Return a LambdaAnswer that is properly configured to invoke the listener.
getLastDeclarationExceptionEvent() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getLastReceive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Get the time the last message was received - initialized to container start time.
getLatch() - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
 
getLatchAnswerFor(String, int) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
Return a LatchCountDownAndCallRealMethodAnswer that is properly configured to invoke the listener.
getLevel() - Method in class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
Get the deflater compression level.
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
 
getMaxFrame(ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Return the negotiated frame_max.
getMaxSenderRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getMessage() - Method in class org.springframework.amqp.core.ReturnedMessage
Get the message.
getMessage() - Method in class org.springframework.amqp.rabbit.batch.MessageBatch
 
getMessage(RetryContext) - Static method in class org.springframework.amqp.support.SendRetryContextAccessor
Retrieve the Message from the context.
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.AbstractRabbitListenerEndpoint
 
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.RabbitListenerEndpoint
Used by the container factory to check if this endpoint supports the preferred way for a container factory to pass a message converter to the endpoint's adapter.
getMessageConverter() - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
 
getMessageCount() - Method in class org.springframework.amqp.core.MessageProperties
Return the server's most recent estimate of the number of messages remaining on the queue.
getMessageCount() - Method in class org.springframework.amqp.core.QueueInformation
 
getMessageCount() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getMessageHandlerMethodFactory() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getMessageHandlerMethodFactory() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
getMessageId() - Method in class org.springframework.amqp.core.MessageProperties
 
getMessageId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getMessageListener() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
 
getMessageListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getMessageListener() - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
Get the message listener.
getMessageProperties() - Method in class org.springframework.amqp.core.Message
 
getMessageProperties() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
The complete MessageProperties from the event representing the event.
getMessagePropertiesConverter() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return the properties converter.
getMessagePropertiesConverter() - 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.adapter.InvocationResult
 
getMethod() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
 
getMethod() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
 
getMethodAsString(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Get the method signature for the payload type via Method.toGenericString().
getMethodFor(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Return the method that will be invoked for this payload.
getMethodFor(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Get the method for the payload type.
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.
getName() - Method in class org.springframework.amqp.core.AbstractExchange
 
getName() - Method in interface org.springframework.amqp.core.Exchange
The name of the exchange.
getName() - Method in class org.springframework.amqp.core.Queue
Return the name provided in the constructor.
getName() - Method in class org.springframework.amqp.core.QueueInformation
 
getNewConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
getNextInvocationDataFor(String, long, TimeUnit) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
 
getNextPublishSeqNo() - Method in class org.springframework.amqp.rabbit.connection.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
 
getObject() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
getObjectType() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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
 
getObjectType() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
 
getOldConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
 
getOrCreateArguments() - Method in class org.springframework.amqp.core.AbstractBuilder
Return the arguments map, after creating one if necessary.
getOrder() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
getOrder() - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
 
getOrder() - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
 
getOrder() - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
 
getPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the password.
getPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the password.
getPassword() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getPendingConfirmsCount(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Get the PendingConfirms count.
getPendingConfirmsCount() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Get the total pending confirms count.
getPendingConfirmsCount(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getPendingConfirmsCount() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getPhase() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
getPhase() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
getPhase() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
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.junit.BrokerRunning
Return the port.
getPort() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the port.
getPort() - Static method in class org.springframework.amqp.rabbit.junit.BrokerTestUtils
The port that the broker is listening on (e.g.
getPort() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getPrefetchCount() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the prefetch count.
getPriority() - Method in class org.springframework.amqp.core.MessageProperties
 
getPriority() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getPriority() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
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.
getPropertyValue(Object, String) - Static method in class org.springframework.amqp.utils.test.TestUtils
Uses nested DirectFieldAccessors to obtain a property using dotted notation to traverse fields; e.g.
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.amqp.utils.test.TestUtils
 
getPublisherConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getPublisherConnectionFactory() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
Return a separate connection factory for publishers (if implemented).
getPublisherConnectionFactoryCacheProperties() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Return the cache properties from the underlying publisher sub-factory.
getPublishSequenceNumber() - Method in class org.springframework.amqp.core.MessageProperties
Return the publish sequence number if publisher confirms are enabled; set by the template.
getQueue() - Method in class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
Obtain the queue name a consumer has been subscribed.
getQueue() - Method in class org.springframework.amqp.rabbit.listener.MissingQueueEvent
Return the missing queue.
getQueue() - Method in class org.springframework.amqp.rabbit.support.Delivery
Retrieve the queue.
getQueuedEventCount() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Return the number of events waiting to be sent.
getQueuedEventCount() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Return the number of events waiting to be sent.
getQueueInfo(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Returns information about the queue, if it exists.
getQueueInfo(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
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
 
getQueueNamesToQueues() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Returns a map of current queue names to the Queue object; allows the determination of a changed broker-named queue.
getQueueProperties(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Returns an implementation-specific Map of properties if the queue exists.
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.listener.AbstractRabbitListenerEndpoint
 
getRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Return a reference to the underlying Rabbit Connection factory.
getRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Access the connection factory to set any other properties not supported by this factory bean.
getRabbitOperations() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
 
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Return the underlying RabbitTemplate used for sending.
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
getReason() - Method in class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
 
getReason() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
 
getReason() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
getReason() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerTerminatedEvent
 
getReceivedDelay() - Method in class org.springframework.amqp.core.MessageProperties
When a delayed message exchange is used the x-delay header on a received message contains the delay.
getReceivedDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
 
getReceivedDeliveryMode() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getReceivedExchange() - Method in class org.springframework.amqp.core.MessageProperties
 
getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
getReceivedExchange() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getReceivedRoutingKey() - Method in class org.springframework.amqp.core.MessageProperties
 
getReceivedRoutingKey() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getReceivedUserId() - Method in class org.springframework.amqp.core.MessageProperties
Return the user id from an incoming message.
getReceivedUserId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getRecoveryBackOff() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
 
getRedelivered() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getRemoteInvocationFactory() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
 
getReplyCode() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getReplyCode() - Method in class org.springframework.amqp.core.ReturnedMessage
Get the reply code.
getReplyContentType() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getReplyContentType() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Get the reply content type.
getReplyContentType() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Get the reply content type.
getReplyPostProcessor() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getReplyPostProcessor() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Return a ReplyPostProcessor to post process a reply message before it is sent.
getReplyText() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getReplyText() - Method in class org.springframework.amqp.core.ReturnedMessage
Get the reply text.
getReplyTo() - Method in class org.springframework.amqp.core.MessageProperties
 
getReplyTo() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getReplyToAddress() - Method in class org.springframework.amqp.core.MessageProperties
 
getReplyToAddress(Message, T) - Method in interface org.springframework.amqp.core.ReplyToAddressCallback
 
getReplyToAddress(Message, Object, InvocationResult) - 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
 
getRequestMessage() - Method in exception org.springframework.amqp.core.AmqpReplyTimeoutException
 
getResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getResourceFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
getResourceLoader() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Get the resource loader; used to resolve the key store and trust store Resources to input streams.
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
 
getResult() - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
 
getRetryOperations() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
getReturned() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getReturned() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Get the returned message and metadata, if any.
getReturnedMessage() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getReturnedMessage() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Deprecated.
getReturnType() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
 
getReturnType() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
 
getReturnTypeFor(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Return the return type for the method that will be chosen for this payload.
getReturnValue() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
 
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.core.Address
 
getRoutingKey() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
getRoutingKey() - Method in class org.springframework.amqp.core.Binding
 
getRoutingKey() - Method in class org.springframework.amqp.core.ReturnedMessage
Get the routing key.
getRoutingKey() - Method in class org.springframework.amqp.rabbit.batch.MessageBatch
 
getRoutingKey() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getRoutingKey() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
 
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.
getSaslConfig() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getSecureRandom() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getSenderPoolSize() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getSendTo() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
 
getShutdownTimeout() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getSource() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
 
getSpy(String) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
 
getSslAlgorithm() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getSslAlgorithm() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getSslPropertiesLocation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getSslPropertiesLocation() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getSyncStatus() - Method in exception org.springframework.amqp.rabbit.connection.AfterCompletionFailedException
Return the synchronization status.
getTargetBean() - Method in class org.springframework.amqp.core.MessageProperties
The target bean when using @RabbitListener.
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.
getTargetMethod() - Method in class org.springframework.amqp.core.MessageProperties
The target method when using a @RabbitListener.
getTaskExecutor() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getTaskExecutor() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
getTaskExecutor() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Get the task executor to use for this endpoint's listener container.
getThrowable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
getThrowable() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
getThrowable() - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
 
getTimestamp() - Method in class org.springframework.amqp.core.MessageProperties
 
getTimestamp() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
 
getTimestamp() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
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(ConnectionFactory, boolean, 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
 
getTransactionAttribute() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getTransactionManager() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
getTrustStore() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStore() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getTrustStoreAlgorithm() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStorePassphrase() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStorePassphrase() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getTrustStoreResource() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
getTrustStoreType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
getTrustStoreType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getType() - Method in class org.springframework.amqp.core.AbstractExchange
 
getType() - Method in class org.springframework.amqp.core.CustomExchange
 
getType() - Method in class org.springframework.amqp.core.DirectExchange
 
getType() - Method in interface org.springframework.amqp.core.Exchange
The type of the exchange.
getType() - Method in class org.springframework.amqp.core.FanoutExchange
 
getType() - Method in class org.springframework.amqp.core.HeadersExchange
 
getType() - Method in class org.springframework.amqp.core.MessageProperties
 
getType() - Method in class org.springframework.amqp.core.TopicExchange
 
getType() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getTypePrecedence() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Return the type precedence.
getTypePrecedence() - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
Return the precedence.
getTypePrecedence() - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
Get the type precedence.
getUnconfirmed(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Gets unconfirmed correlation data older than age and removes them.
getUnconfirmedCount() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Gets unconfirmed messages count.
getUri() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Return the user.
getUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Return the user.
getUserId() - Method in class org.springframework.amqp.core.MessageProperties
 
getUserId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
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.logback.AmqpAppender
 
getUUID() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
Returns the UUID used to identify this Listener for returns.
getUUID() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
getValidator() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Get the validator, if supplied.
getValue() - Method in enum org.springframework.amqp.core.QueueBuilder.LeaderLocator
Return the value.
getValue() - Method in enum org.springframework.amqp.core.QueueBuilder.MasterLocator
Deprecated.
Return the value.
getValue() - Method in enum org.springframework.amqp.core.QueueBuilder.Overflow
Return the value.
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.logback.AmqpAppender
 
getXDeathHeader() - Method in class org.springframework.amqp.core.MessageProperties
Return the x-death header.
GUnzipPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a GZIPInputStream to decompress the message body.
GUnzipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
 
GUnzipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
 
GZipPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a GZIPOutputStream to compress the message body.
GZipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.GZipPostProcessor
 
GZipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.GZipPostProcessor
 

H

handle(R) - Method in interface org.springframework.amqp.core.ReceiveAndReplyCallback
 
handle(Return) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
handle(Error) - Method in interface org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.JavaLangErrorHandler
Handle the error; typically, the JVM will be terminated.
handleAck(long, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
handleConfirm(PendingConfirm, boolean) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
Invoked by the channel when a confirm is received.
handleConfirm(PendingConfirm, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleDiscarded(Message) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Called when a message with a fatal exception has an x-death header, prior to discarding the message.
handleError(Message, Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.amqp.rabbit.listener.api.RabbitListenerErrorHandler
Handle the error.
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.
handleMessage(T) - Method in interface org.springframework.amqp.rabbit.listener.adapter.ReplyingMessageListener
Handle the message and return a reply.
handleNack(long, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
HandlerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Construct an instance with the provided method.
HandlerAdapter(DelegatingInvocableHandler) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Construct an instance with the provided delegating handler.
handleRecovery(Recoverable) - Method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
 
handleRecoveryStarted(Recoverable) - Method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
 
handleResult(InvocationResult, 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(InvocationResult, 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 interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
handleReturn(Return) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
Handle a returned message.
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleReturn(Return) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleStartupFailure(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
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.
hasDefaultHandler() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
 
hasDelivery() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
hashCode() - Method in class org.springframework.amqp.core.Address
 
hashCode() - Method in class org.springframework.amqp.core.Message
 
hashCode() - Method in class org.springframework.amqp.core.MessageProperties
 
hashCode() - Method in class org.springframework.amqp.core.QueueInformation
 
hashCode() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
hasInferredTypeHeader(MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
hasPublisherConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
HEADERS - Static variable in class org.springframework.amqp.core.ExchangeTypes
Headers exchange.
headersExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
Return a HeadersExchange builder.
HeadersExchange - Class in org.springframework.amqp.core
Headers exchange.
HeadersExchange(String) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchangeParser - Class in org.springframework.amqp.rabbit.config
 
HeadersExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 

I

ignoreDeclarationExceptions() - Method in class org.springframework.amqp.core.ExchangeBuilder
Switch on ignore exceptions such as mismatched properties when declaring.
ImmediateAcknowledgeAmqpException - Exception in org.springframework.amqp
Special exception for listener implementations that want to signal that the current batch of messages should be acknowledged immediately (i.e.
ImmediateAcknowledgeAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
 
ImmediateAcknowledgeAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
 
ImmediateAcknowledgeAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
 
ImmediateRequeueAmqpException - Exception in org.springframework.amqp
The special AmqpException to be thrown from the listener (e.g.
ImmediateRequeueAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
 
ImmediateRequeueAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
 
ImmediateRequeueAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
 
ImmediateRequeueMessageRecoverer - Class in org.springframework.amqp.rabbit.retry
The MessageRecoverer implementation to throw an ImmediateRequeueAmqpException for subsequent requeuing in the listener container.
ImmediateRequeueMessageRecoverer() - Constructor for class org.springframework.amqp.rabbit.retry.ImmediateRequeueMessageRecoverer
 
incrementRetries() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
 
incrementRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
InflaterPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a InflaterInputStream to decompress the message body.
InflaterPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
 
InflaterPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
 
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 interface org.springframework.amqp.core.AmqpAdmin
Initialize the admin.
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, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Further initialize the specified container.
initializeContainer(DirectMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
 
initializeContainer(SimpleMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
initializeProxy(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
INSTANCE - Static variable in class org.springframework.amqp.utils.JavaUtils
The singleton instance of this utility class.
internal() - Method in class org.springframework.amqp.core.ExchangeBuilder
Set the internal flag.
InvocationData(MethodInvocation, Object) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
 
InvocationData(MethodInvocation, Throwable) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
 
InvocationResult - Class in org.springframework.amqp.rabbit.listener.adapter
The result of a listener method invocation.
InvocationResult(Object, Expression, Type, Object, Method) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
Construct an instance with the provided properties.
invoke(RabbitOperations.OperationsCallback<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Invoke the callback and run all operations on the template argument in a dedicated thread-bound channel and reliably close the channel afterwards.
invoke(RabbitOperations.OperationsCallback<T>, ConfirmCallback, ConfirmCallback) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Invoke operations on the same channel.
invoke(RabbitOperations.OperationsCallback<T>, ConfirmCallback, ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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 the appropriate method for the payload.
invoke(MethodInvocation) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
 
invokeErrorHandler(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the registered ErrorHandler, if any.
invokeHandlerAndProcessResult(Message, Channel, Message<?>) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
invokeListener(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
invokeListenerMethod(String, Object[], Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Invoke the specified listener method.
isAck() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
 
isActive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isActive() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
isAddMdcAsHeaders() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isAlwaysRequeueWithTxManagerRollback() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isAmqpMessageList() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
 
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.
isAutoAck() - Method in enum org.springframework.amqp.core.AcknowledgeMode
Return if the mode is AcknowledgeMode.NONE (which is called autoAck in RabbitMQ).
isAutoDeclare() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isAutoDelete() - Method in class org.springframework.amqp.core.AbstractExchange
 
isAutoDelete() - Method in interface org.springframework.amqp.core.Exchange
True if the server should delete the exchange when it is no longer in use (if all bindings are deleted).
isAutoDelete() - Method in class org.springframework.amqp.core.Queue
True if the server should delete the queue when it is no longer in use (the last consumer is cancelled).
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.config.ListenerContainerFactoryBean
 
isAutoStartup() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
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
 
isBatchListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
isBrokerAndManagementRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
isBrokerAndManagementRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
isBrokerAndManagementRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
isBrokerAndManagementRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
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() - 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.
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.
isConfirmListener() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
 
isConfirmListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
isConfirmSelected() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
Return true if confirms are selected on this channel.
isConsumerBatchEnabled() - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
Return true if this container is capable of (and configured to) create batches of consumed messages.
isConsumerBatchEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
isContentLengthSet() - Method in class org.springframework.amqp.core.MessageProperties
 
isConverterWinsContentType() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
isConverterWinsContentType() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Return whether the content type set by a converter prevails or not.
isConverterWinsContentType() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Return whether the content type set by a converter prevails or not.
isCreateMessageIds() - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
Flag to indicate that new messages should have unique identifiers added to their properties before sending.
isDeBatchingEnabled() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isDeclareExchange() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isDefaultRequeueRejected() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the default requeue rejected.
isDelayed() - Method in class org.springframework.amqp.core.AbstractExchange
 
isDelayed() - Method in interface org.springframework.amqp.core.Exchange
Is a delayed message exchange; currently requires a broker plugin.
isDeliveryTagSet() - Method in class org.springframework.amqp.core.MessageProperties
 
isDestinationQueue() - Method in class org.springframework.amqp.core.Binding
 
isDiscardFatalsWithXDeath() - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Return the discardFatalsWithXDeath.
isDurable() - Method in class org.springframework.amqp.core.AbstractExchange
 
isDurable() - Method in interface org.springframework.amqp.core.Exchange
A durable exchange will survive a server restart.
isDurable() - Method in class org.springframework.amqp.core.Queue
A durable queue will survive a server restart.
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.core.Queue
True if the server should only send messages to the declarer's connection.
isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return whether the consumers should be exclusive.
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
 
isFinalRetryForMessageWithNoId() - Method in class org.springframework.amqp.core.MessageProperties
 
isForceCloseChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Force close the channel if the consumer threads don't respond to a shutdown.
isGenerateId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isGlobalQos() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isIgnoreDeclarationExceptions() - Method in class org.springframework.amqp.core.AbstractDeclarable
 
isIgnoreDeclarationExceptions() - Method in interface org.springframework.amqp.core.Declarable
Should ignore exceptions (such as mismatched args) when declaring.
isIncludeCallerData() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isInternal() - Method in class org.springframework.amqp.core.AbstractExchange
 
isInternal() - Method in interface org.springframework.amqp.core.Exchange
Is an exchange internal; i.e.
isLastInBatch() - Method in class org.springframework.amqp.core.MessageProperties
When true; the message having these properties is the last message from a batch.
isLenientFallback() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
isMandatoryFor(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return whether the provided message should be sent with the mandatory flag set.
isManual() - Method in enum org.springframework.amqp.core.AcknowledgeMode
Return true if the mode is AcknowledgeMode.MANUAL.
isMessageList() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
 
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.
isMismatchedQueuesFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isMissingQueuesFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isMissingQueuesFatalSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
Query a message to see if it has been seen before.
isNoLocal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return whether the consumers should be no-local.
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".
isNotRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
isNotRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
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.PublisherCallbackChannelImpl
 
isOpen() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
True if the connection is open.
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.
isPossibleAuthenticationFailureFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isPossibleAuthenticationFailureFatalSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
Return true if publisher confirms are enabled.
isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isPublisherReturns() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
Return true if publisher returns are enabled.
isPurgeAfterEach() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
isRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
 
isRejectManual() - Method in exception org.springframework.amqp.AmqpRejectAndDontRequeueException
True if the container should reject the message, even with manual acks.
isRejectManual() - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Return the rejectManual.
isRejectManual(Throwable) - Static method in class org.springframework.amqp.rabbit.listener.support.ContainerUtils
isReleaseAfterCompletion() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
Whether the resources should be released after transaction completion.
isReturned() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
True if a returned message has been received.
isReturnListener() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
 
isReturnListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
isRunning() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
isRunning() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
isRunning() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
 
isRunning() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
isRunning() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
 
isRunning() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
isRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
isRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
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
 
isRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Ensure the broker is running and has a empty queue(s) with the specified name(s) in the default exchange.
isRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Ensure the broker is running and has a empty queue(s) with the specified name(s) in the default exchange.
isShouldRun() - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
Return true if the test should run.
isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
isSimplePublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
Return true if simple publisher confirms are enabled.
isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
 
isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
 
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
 
isSingleton() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
 
isSkipServerCertificateValidation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not Server Side certificate has to be validated or not.
isStatefulRetryFatalWithNullMessageId() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
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().
isTransactionAllowed() - Method in enum org.springframework.amqp.core.AcknowledgeMode
Return if transactions are allowed - if the mode is AcknowledgeMode.AUTO or AcknowledgeMode.MANUAL.
isTypeMapperSet() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Whether or not an explicit java type mapper has been provided.
isUp() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
isUseProjectionForInterfaces() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
isUsePublisherConnection() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
True if separate publisher connection(s) are used.
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
 
isUseSsl() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
isVerifyHostname() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Return true (default) if TLS hostname verification is enabled.
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
 

J

Jackson2JavaTypeMapper - Interface in org.springframework.amqp.support.converter
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
Jackson2JavaTypeMapper.TypePrecedence - Enum in org.springframework.amqp.support.converter
The precedence for type conversion - inferred from the method parameter or message headers.
Jackson2JsonMessageConverter - Class in org.springframework.amqp.support.converter
JSON converter that uses the Jackson 2 Json library.
Jackson2JsonMessageConverter() - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
Construct with an internal ObjectMapper instance and trusted packed to all (*).
Jackson2JsonMessageConverter(String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
Construct with an internal ObjectMapper instance.
Jackson2JsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
Construct with the provided ObjectMapper instance and trusted packed to all (*).
Jackson2JsonMessageConverter(ObjectMapper, String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
Construct with the provided ObjectMapper instance.
Jackson2XmlMessageConverter - Class in org.springframework.amqp.support.converter
XML converter that uses the Jackson 2 Xml library.
Jackson2XmlMessageConverter() - Constructor for class org.springframework.amqp.support.converter.Jackson2XmlMessageConverter
Construct with an internal XmlMapper instance and trusted packed to all (*).
Jackson2XmlMessageConverter(String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2XmlMessageConverter
Construct with an internal XmlMapper instance.
Jackson2XmlMessageConverter(XmlMapper) - Constructor for class org.springframework.amqp.support.converter.Jackson2XmlMessageConverter
Construct with the provided XmlMapper instance and trusted packed to all (*).
Jackson2XmlMessageConverter(XmlMapper, String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2XmlMessageConverter
Construct with the provided XmlMapper instance.
JavaUtils - Class in org.springframework.amqp.utils
Chained utility methods to simplify some Java repetitive code.
JUnitUtils - Class in org.springframework.amqp.rabbit.junit
Utility methods for JUnit rules and conditions.
JUnitUtils.LevelsContainer - Class in org.springframework.amqp.rabbit.junit
 

L

LambdaAnswer<T> - Class in org.springframework.amqp.rabbit.test.mockito
An Answer to optionally call the real method and allow returning a custom result.
LambdaAnswer(boolean, LambdaAnswer.ValueToReturn<T>) - Constructor for class org.springframework.amqp.rabbit.test.mockito.LambdaAnswer
LambdaAnswer(boolean, LambdaAnswer.ValueToReturn<T>, Object) - Constructor for class org.springframework.amqp.rabbit.test.mockito.LambdaAnswer
Construct an instance with the provided properties.
LambdaAnswer.ValueToReturn<T> - Interface in org.springframework.amqp.rabbit.test.mockito
 
LAST_IN_BATCH - Static variable in class org.springframework.amqp.support.AmqpHeaders
A flag to indicate that the current message is the last from a batch.
LatchCountDownAndCallRealMethodAnswer - Class in org.springframework.amqp.rabbit.test.mockito
An Answer for void returning methods that calls the real method and counts down a latch.
LatchCountDownAndCallRealMethodAnswer(int) - Constructor for class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
LatchCountDownAndCallRealMethodAnswer(int, Object) - Constructor for class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
Get an instance with the provided properties.
lazy() - Method in class org.springframework.amqp.core.QueueBuilder
Set the queue into lazy mode, keeping as many messages as possible on disk to reduce RAM usage on the broker.
lazyLoad() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
lazyLoad() - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
Do not check for missing or mismatched queues during startup.
leaderLocator(QueueBuilder.LeaderLocator) - Method in class org.springframework.amqp.core.QueueBuilder
Set the master locator mode which determines which node a queue master will be located on a cluster of nodes.
LevelsContainer(Map<Class<?>, Level>, Map<String, Level>, Map<String, Level>) - Constructor for class org.springframework.amqp.rabbit.junit.JUnitUtils.LevelsContainer
 
ListenerContainerAware - Interface in org.springframework.amqp.rabbit.support
MessageListeners 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.
ListenerContainerConsumerTerminatedEvent - Class in org.springframework.amqp.rabbit.listener
Published when a listener consumer is terminated.
ListenerContainerConsumerTerminatedEvent(Object, String) - Constructor for class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerTerminatedEvent
Construct an instance with the provided arguments.
ListenerContainerFactoryBean - Class in org.springframework.amqp.rabbit.config
A Factory bean to create a listener container.
ListenerContainerFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
ListenerContainerFactoryBean.Type - Enum in org.springframework.amqp.rabbit.config
The container type.
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.support
Exception to be thrown when the execution of a listener method failed.
ListenerExecutionFailedException(String, Throwable, Message...) - Constructor for exception org.springframework.amqp.rabbit.support.ListenerExecutionFailedException
Constructor for ListenerExecutionFailedException.
ListenerFailedRuleBasedTransactionAttribute - Class in org.springframework.amqp.rabbit.listener
Subclass of RuleBasedTransactionAttribute that is aware that listener exceptions are wrapped in ListenerExecutionFailedExceptions.
ListenerFailedRuleBasedTransactionAttribute() - Constructor for class org.springframework.amqp.rabbit.listener.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
 
log(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Log the throwable at WARN level, including stack trace.
log(Log, String, Throwable) - Method in interface org.springframework.amqp.support.ConditionalExceptionLogger
Log the event.
log - Variable in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
logFatalException(ListenerExecutionFailedException, Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
Log the fatal ListenerExecutionFailedException at WARN level, excluding stack trace.
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.ImmediateRequeueMessageRecoverer
 
logger - Variable in class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
 
logger - Variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
logger - Variable in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
 
LogLevelAdjuster - Class in org.springframework.amqp.rabbit.junit
A JUnit method @Rule that changes the logger level for a set of classes while a test method is running.
LogLevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.amqp.rabbit.junit.LogLevelAdjuster
 
LogLevels - Annotation Type in org.springframework.amqp.rabbit.junit
Test classes annotated with this will change logging levels between tests.
LogLevelsCondition - Class in org.springframework.amqp.rabbit.junit
JUnit condition that adjusts and reverts log levels before/after each test.
LogLevelsCondition() - Constructor for class org.springframework.amqp.rabbit.junit.LogLevelsCondition
 
LongRunning - Annotation Type in org.springframework.amqp.rabbit.junit
Test classes annotated with this will not run if an environment variable or system property (default RUN_LONG_INTEGRATION_TESTS) is not present or does not have the value that Boolean.parseBoolean(String) evaluates to true.
LongRunningIntegrationTest - Class in org.springframework.amqp.rabbit.junit
Rule to prevent long running tests from running on every build; set environment variable RUN_LONG_INTEGRATION_TESTS on a CI nightly build to ensure coverage.
LongRunningIntegrationTest() - Constructor for class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
 
LongRunningIntegrationTest(String) - Constructor for class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
Check using a custom variable/property name.
LongRunningIntegrationTestCondition - Class in org.springframework.amqp.rabbit.junit
ExecutionCondition to skip long running tests unless an environment variable or property is set.
LongRunningIntegrationTestCondition() - Constructor for class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTestCondition
 

M

MapBuilder<B extends MapBuilder<B,K,V>,K,V> - Class in org.springframework.amqp.utils
A Builder pattern implementation for a Map.
MapBuilder() - Constructor for class org.springframework.amqp.utils.MapBuilder
 
MarshallingMessageConverter - Class in org.springframework.amqp.support.converter
Spring Rabbit MessageConverter that uses a Marshaller and Unmarshaller.
MarshallingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with no Marshaller or Unmarshaller set.
MarshallingMessageConverter(Marshaller) - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller set.
MarshallingMessageConverter(Marshaller, Unmarshaller) - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller and Unmarshaller.
masterLocator(QueueBuilder.MasterLocator) - Method in class org.springframework.amqp.core.QueueBuilder
match() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeMapBindingCreator
 
matches(Object) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator
 
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.
maxLength(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the number of (ready) messages allowed in the queue before it starts to drop them.
maxLengthBytes(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the total aggregate body size allowed in the queue before it starts to drop them.
maxPriority(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the maximum number if priority levels for the queue to support; if not set, the queue will not support message priorities.
Message - Class in org.springframework.amqp.core
The 0-8 and 0-9-1 AMQP specifications do not define an Message class or interface.
Message(byte[]) - Constructor for class org.springframework.amqp.core.Message
Construct an instance with the provided body and default MessageProperties.
Message(byte[], MessageProperties) - Constructor for class org.springframework.amqp.core.Message
Construct an instance with the provided body and properties.
MESSAGE - Static variable in class org.springframework.amqp.support.SendRetryContextAccessor
Key for the message we tried to send.
MESSAGE_COUNT - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
MESSAGE_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
MessageBatch - Class in org.springframework.amqp.rabbit.batch
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.batch.MessageBatch
 
MessageBatchRecoverer - Interface in org.springframework.amqp.rabbit.retry
A retry recoverer for use with a batch listener.
MessageBuilder - Class in org.springframework.amqp.core
Builds a Spring AMQP Message either from a byte[] body or another Message using a fluent API.
MessageBuilderSupport<T> - Class in org.springframework.amqp.core
Support class for building Message and MessageProperties fluent API.
MessageBuilderSupport() - Constructor for class org.springframework.amqp.core.MessageBuilderSupport
 
MessageBuilderSupport(MessageProperties) - Constructor for class org.springframework.amqp.core.MessageBuilderSupport
 
MessageConversionException - Exception in org.springframework.amqp.support.converter
Exception to be thrown by message converters if they encounter a problem with converting a message or object.
MessageConversionException(String, Throwable) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
MessageConversionException(String) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
MessageConverter - Interface in org.springframework.amqp.support.converter
Message converter interface.
messageCount(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
MessageDeliveryMode - Enum in org.springframework.amqp.core
Enumeration for the message delivery mode.
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
 
MessageListener - Interface in org.springframework.amqp.core
Listener interface to receive asynchronous delivery of Amqp Messages.
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.
MessagePostProcessor - Interface in org.springframework.amqp.core
Used in several places in the framework, such as AmqpTemplate#convertAndSend(Object, MessagePostProcessor) where it can be used to add/modify headers or properties after the message conversion has been performed.
MessagePostProcessorUtils - Class in org.springframework.amqp.support.postprocessor
Utilities for message post processors.
MessageProperties - Class in org.springframework.amqp.core
Message Properties for an AMQP message.
MessageProperties() - Constructor for class org.springframework.amqp.core.MessageProperties
 
MessagePropertiesBuilder - Class in org.springframework.amqp.core
Builds a Spring AMQP MessageProperties object using a fluent API.
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
Exception class that indicates a rejected message on shutdown.
MessageRejectedWhileStoppingException() - Constructor for exception org.springframework.amqp.rabbit.listener.exception.MessageRejectedWhileStoppingException
 
MessagingMessageConverter - Class in org.springframework.amqp.support.converter
Convert a Message from the messaging abstraction to and from a Message using an underlying MessageConverter for the payload and a AmqpHeaderMapper to map the AMQP headers to and from standard message headers.
MessagingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.MessagingMessageConverter
Create an instance with a default payload converter for an inbound handler.
MessagingMessageConverter(MessageConverter, AmqpHeaderMapper) - Constructor for class org.springframework.amqp.support.converter.MessagingMessageConverter
Create an instance with the specified payload converter and header mapper.
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
 
MessagingMessageListenerAdapter(Object, Method, boolean, RabbitListenerErrorHandler) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
MessagingMessageListenerAdapter(Object, Method, boolean, RabbitListenerErrorHandler, boolean) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
MessagingMessageListenerAdapter.MessagingMessageConverterAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
Delegates payload extraction to AbstractAdaptableMessageListener.extractMessage(org.springframework.amqp.core.Message message) to enforce backward compatibility.
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
 
MissingQueueEvent - Class in org.springframework.amqp.rabbit.listener
Event published when a missing queue is detected.
MissingQueueEvent(Object, String) - Constructor for class org.springframework.amqp.rabbit.listener.MissingQueueEvent
Construct an instance with the provided source and queue.
MULTI_RABBIT_ADMIN_SUFFIX - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The MultiRabbit admins' suffix.
MULTI_RABBIT_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The bean name of the ContainerFactory of the default broker for MultiRabbit.
MULTI_RABBIT_ENABLED_PROPERTY - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The default property to enable/disable MultiRabbit processing.
MultiMethodRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.listener
 
MultiMethodRabbitListenerEndpoint(List<Method>, Object) - Constructor for class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
Construct an instance for the provided methods and bean.
MultiMethodRabbitListenerEndpoint(List<Method>, Method, Object) - Constructor for class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
Construct an instance for the provided methods, default method and bean.
MultiRabbitBootstrapConfiguration - Class in org.springframework.amqp.rabbit.annotation
An ImportBeanDefinitionRegistrar class that registers a MultiRabbitListenerAnnotationBeanPostProcessor bean, if MultiRabbit is enabled.
MultiRabbitBootstrapConfiguration() - Constructor for class org.springframework.amqp.rabbit.annotation.MultiRabbitBootstrapConfiguration
 
MultiRabbitListenerAnnotationBeanPostProcessor - Class in org.springframework.amqp.rabbit.annotation
An extension of RabbitListenerAnnotationBeanPostProcessor that indicates the proper RabbitAdmin bean to be used when processing to the listeners, and also associates it to the declarables (Exchanges, Queues, and Bindings) returned.
MultiRabbitListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.amqp.rabbit.annotation.MultiRabbitListenerAnnotationBeanPostProcessor
 

N

name - Variable in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
NamespaceUtils - Class in org.springframework.amqp.rabbit.config
Shared utility methods for namespace parsers.
NamespaceUtils() - Constructor for class org.springframework.amqp.rabbit.config.NamespaceUtils
 
NamingStrategy - Interface in org.springframework.amqp.core
A strategy to generate names.
newBuilder() - Static method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Create a new builder.
newInstance() - Static method in class org.springframework.amqp.core.MessagePropertiesBuilder
Returns a builder with an initial set of properties.
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.batch.BatchingStrategy
 
nextRelease() - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
 
noargs() - Method in class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
 
noBeanFoundMessage(Object, String, String, Class<?>) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
nonDurable() - Static method in class org.springframework.amqp.core.QueueBuilder
Creates a builder for a non-durable (transient) queue.
nonDurable(String) - Static method in class org.springframework.amqp.core.QueueBuilder
Creates a builder for a non-durable (transient) queue.
notifyListeners() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
nullSafeExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return the exchange or the default exchange if null.
nullSafeRoutingKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return the routing key or the default routing key if null.

O

objectMapper - Variable in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
obtainNewConnectionName(ConnectionFactory) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionNameStrategy
 
obtainNewConnectionName(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
 
onApplicationEvent(ContextClosedEvent) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
onClose(Connection) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onClose(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
Called when a connection is closed.
onClose(Connection) - Method in class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
 
onCreate(Channel, boolean) - Method in interface org.springframework.amqp.rabbit.connection.ChannelListener
Called when a new channel is created.
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
Called when a new connection is established.
onCreate(Channel, boolean) - Method in interface org.springframework.amqp.rabbit.connection.ShutDownChannelListener
 
onCreate(Connection) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
onCreate(Connection) - Method in class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
 
onFailed(Exception) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onFailed(Exception) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
Called when a connection couldn't be established.
onMessage(Message) - Method in interface org.springframework.amqp.core.BatchMessageListener
 
onMessage(Message) - Method in interface org.springframework.amqp.core.MessageListener
Delivers a single message.
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
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
 
onMessage(Message, Channel) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareBatchMessageListener
 
onMessage(Message, Channel) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareMessageListener
Callback for processing a received Rabbit message.
onMessage(Message) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareMessageListener
 
onMessage(Message) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
 
onMessageBatch(List<Message>) - Method in interface org.springframework.amqp.core.BatchMessageListener
 
onMessageBatch(List<Message>) - Method in interface org.springframework.amqp.core.MessageListener
Delivers a batch of messages.
onMessageBatch(List<Message>, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.BatchMessagingMessageListenerAdapter
 
onMessageBatch(List<Message>, Channel) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareBatchMessageListener
 
onMessageBatch(List<Message>, Channel) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareMessageListener
 
onShutDown(ShutdownSignalException) - Method in interface org.springframework.amqp.rabbit.connection.ChannelListener
Called when the underlying RabbitMQ channel is closed for any reason.
onShutDown(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
onShutDown(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onShutDown(ShutdownSignalException) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
Called when a connection is force closed.
onShutDown(ShutdownSignalException) - Method in interface org.springframework.amqp.rabbit.connection.ShutDownChannelListener
 
ORDER - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
org.springframework.amqp - package org.springframework.amqp
Base package for Spring AMQP.
org.springframework.amqp.core - package org.springframework.amqp.core
Provides core classes for the spring AMQP abstraction.
org.springframework.amqp.event - package org.springframework.amqp.event
Classes related to application events
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.batch - package org.springframework.amqp.rabbit.batch
Provides classes for message batching.
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.junit - package org.springframework.amqp.rabbit.junit
Provides support classes (Rules etc.
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.api - package org.springframework.amqp.rabbit.listener.api
Provides Additional APIs for listeners.
org.springframework.amqp.rabbit.listener.exception - package org.springframework.amqp.rabbit.listener.exception
Provides classes for listener exceptions.
org.springframework.amqp.rabbit.listener.support - package org.springframework.amqp.rabbit.listener.support
Provides support classes for listeners.
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.test - package org.springframework.amqp.rabbit.test
Classes for testing Spring AMQP applications.
org.springframework.amqp.rabbit.test.context - package org.springframework.amqp.rabbit.test.context
Provides classes relating to the test application context.
org.springframework.amqp.rabbit.test.mockito - package org.springframework.amqp.rabbit.test.mockito
Mockito extensions for testing Spring AMQP applications.
org.springframework.amqp.rabbit.transaction - package org.springframework.amqp.rabbit.transaction
Provides classes supporting transactions in Spring Rabbit.
org.springframework.amqp.remoting.client - package org.springframework.amqp.remoting.client
Provides classes for the client side of Spring Remoting over AMQP.
org.springframework.amqp.remoting.service - package org.springframework.amqp.remoting.service
Provides classes for the service side of Spring Remoting over AMQP.
org.springframework.amqp.support - package org.springframework.amqp.support
Package for Spring AMQP support classes.
org.springframework.amqp.support.converter - package org.springframework.amqp.support.converter
Provides classes for supporting message conversion.
org.springframework.amqp.support.postprocessor - package org.springframework.amqp.support.postprocessor
Package for Spring AMQP message post processors.
org.springframework.amqp.utils - package org.springframework.amqp.utils
Provides utility classes to support Spring AMQP.
org.springframework.amqp.utils.test - package org.springframework.amqp.utils.test
 
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".
overflow(QueueBuilder.Overflow) - Method in class org.springframework.amqp.core.QueueBuilder
Set the overflow mode when messages are dropped due to max messages or max message size is exceeded.

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
 
parseBooleanProperty(String) - Static method in class org.springframework.amqp.rabbit.junit.JUnitUtils
Return the parsed value if the provided property exists in the environment or system properties.
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
 
PendingConfirm - Class in org.springframework.amqp.rabbit.connection
Instances of this object track pending publisher confirms.
PendingConfirm(CorrelationData, long) - Constructor for class org.springframework.amqp.rabbit.connection.PendingConfirm
 
PooledChannelConnectionFactory - Class in org.springframework.amqp.rabbit.connection
A very simple connection factory that caches channels using Apache Pool2 GenericObjectPools (one for transactional and one for non-transactional channels).
PooledChannelConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
Construct an instance.
pop(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Unbind the current value and bind the head of the stack if present.
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.
postProcessMessage(Message) - Method in interface org.springframework.amqp.core.MessagePostProcessor
Change (or replace) the message.
postProcessMessage(Message, Correlation) - Method in interface org.springframework.amqp.core.MessagePostProcessor
Change (or replace) the message and/or change its correlation data.
postProcessMessage(Message, Correlation, String, String) - Method in interface org.springframework.amqp.core.MessagePostProcessor
Change (or replace) the message and/or change its correlation data.
postProcessMessage(Message) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
 
postProcessMessage(Message) - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
 
postProcessMessage(Message) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
 
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.
PREFIX - Static variable in class org.springframework.amqp.support.AmqpHeaders
Prefix used for AMQP related headers in order to distinguish from user-defined headers and other internal headers (e.g.
prepareHolderForRollback(RabbitResourceHolder, RuntimeException) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
A null resource holder is rare, but possible if the transaction attribute caused no transaction to be started (e.g.
prepareMessageProperties(AmqpAppender.Event) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
prepareSwitchContext() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Call to prepare to switch the channel(s) owned by this thread to another thread.
PRIORITY - Static variable in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
processAmqpListener(RabbitListener, Method, Object, String) - Method in class org.springframework.amqp.rabbit.annotation.MultiRabbitListenerAnnotationBeanPostProcessor
 
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
 
processListener(MethodRabbitListenerEndpoint, RabbitListener, Object, Object, String) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
 
processMonitorTask() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Subclasses can override this to take additional actions when the monitor task runs.
processMonitorTask() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
ProjectingMessageConverter - Class in org.springframework.amqp.support.converter
Uses a Spring Data ProjectionFactory to bind incoming messages to projection interfaces.
ProjectingMessageConverter(ObjectMapper) - Constructor for class org.springframework.amqp.support.converter.ProjectingMessageConverter
 
PUBLISH_CONFIRM - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
PUBLISH_CONFIRM_CORRELATION - Static variable in class org.springframework.amqp.support.AmqpHeaders
A CorrelationData instance for publisher confirms (not mapped).
PUBLISH_CONFIRM_NACK_CAUSE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
publishConsumerFailedEvent(String, boolean, Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
publishConsumerFailedEvent(String, boolean, Throwable) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
PublisherCallbackChannel - Interface in org.springframework.amqp.rabbit.connection
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.connection
Listeners implementing this interface can participate in publisher confirms received from multiple channels, by invoking addListener on each channel.
PublisherCallbackChannelFactory - Interface in org.springframework.amqp.rabbit.connection
A factory for PublisherCallbackChannels.
PublisherCallbackChannelImpl - Class in org.springframework.amqp.rabbit.connection
Channel wrapper to allow a single listener able to handle confirms from multiple channels.
PublisherCallbackChannelImpl(Channel, ExecutorService) - Constructor for class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Create a PublisherCallbackChannelImpl instance based on the provided delegate and executor.
publishIdleContainerEvent(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
publishMissingQueueEvent(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
purgeQueue(String, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
Purges the contents of the given queue.
purgeQueue(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Purges the contents of the given queue.
purgeQueue(String, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
purgeQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
purgeTestQueues() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Delete and re-declare all the configured queues.
purgeTestQueues() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Delete and re-declare all the configured queues.
push(Object, Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Set the value for this key and push any existing value onto a stack.
put(K, V) - Method in class org.springframework.amqp.utils.MapBuilder
 

Q

Queue - Class in org.springframework.amqp.core
Simple container collecting information to describe a queue.
Queue(String) - Constructor for class org.springframework.amqp.core.Queue
The queue is durable, non-exclusive and non auto-delete.
Queue(String, boolean) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name and durability flag.
Queue(String, boolean, boolean, boolean) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name, durability, exclusive and auto-delete flags.
Queue(String, boolean, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name, durability flag, and auto-delete flag, and arguments.
Queue - Annotation Type in org.springframework.amqp.rabbit.annotation
A queue definition used within the bindings attribute of a QueueBinding.
QUEUE_CLASS_ID_50 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
AMQP queue class id.
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.connection.PublisherCallbackChannelImpl
 
queueBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.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.connection.PublisherCallbackChannelImpl
 
QueueBuilder - Class in org.springframework.amqp.core
Builds a Spring AMQP Queue using a fluent API.
QueueBuilder.LeaderLocator - Enum in org.springframework.amqp.core
Locate the queue leader.
QueueBuilder.MasterLocator - Enum in org.springframework.amqp.core
Deprecated.
QueueBuilder.Overflow - Enum in org.springframework.amqp.core
Overflow argument values.
queueDeclare() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDeclare(String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDeclareNoWait(String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDelete(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDelete(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
queueDeleteNoWait(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
QueueInformation - Class in org.springframework.amqp.core
Information about a queue, resulting from a passive declaration.
QueueInformation(String, int, int) - Constructor for class org.springframework.amqp.core.QueueInformation
 
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.connection.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.connection.PublisherCallbackChannelImpl
 
queueUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
quorum() - Method in class org.springframework.amqp.core.QueueBuilder
Set the queue argument to declare a queue of type 'quorum' instead of 'classic'.

R

RABBIT_ADMIN_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The bean name of the default RabbitAdmin.
RABBIT_CONNECTION_FACTORY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
The bean name of the default ConnectionFactory.
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
Construct an instance using the provided ConnectionFactory.
RabbitAdmin(RabbitTemplate) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdmin
Construct an instance using the provided RabbitTemplate.
RabbitAdminEvent - Class in org.springframework.amqp.rabbit.core
Base class for admin events.
RabbitAdminEvent(Object) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdminEvent
 
RabbitAvailable - Annotation Type in org.springframework.amqp.rabbit.junit
Test classes annotated with this will not run if there is no broker on localhost.
RabbitAvailableCondition - Class in org.springframework.amqp.rabbit.junit
JUnit5 ExecutionCondition.
RabbitAvailableCondition() - Constructor for class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
RabbitBootstrapConfiguration - Class in org.springframework.amqp.rabbit.annotation
An ImportBeanDefinitionRegistrar 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
 
RabbitListenerConfigurationSelector - Class in org.springframework.amqp.rabbit.annotation
A DeferredImportSelector implementation with the lowest order to import a MultiRabbitBootstrapConfiguration and RabbitBootstrapConfiguration as late as possible.
RabbitListenerConfigurationSelector() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurationSelector
 
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
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
 
RabbitListenerErrorHandler - Interface in org.springframework.amqp.rabbit.listener.api
An error handler which is called when a {code @RabbitListener} method throws an exception.
RabbitListeners - Annotation Type in org.springframework.amqp.rabbit.annotation
Container annotation that aggregates several RabbitListener annotations.
RabbitListenerTest - Annotation Type in org.springframework.amqp.rabbit.test
Annotate a @Configuration class with this to enable proxying @RabbitListener beans to capture arguments and result (if any).
RabbitListenerTestBootstrap - Class in org.springframework.amqp.rabbit.test
Overrides the default BPP with a RabbitListenerTestHarness.
RabbitListenerTestBootstrap() - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestBootstrap
 
RabbitListenerTestHarness - Class in org.springframework.amqp.rabbit.test
BeanPostProcessor extending RabbitListenerAnnotationBeanPostProcessor.
RabbitListenerTestHarness(AnnotationMetadata) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
 
RabbitListenerTestHarness.InvocationData - Class in org.springframework.amqp.rabbit.test
 
RabbitListenerTestSelector - Class in org.springframework.amqp.rabbit.test
A RabbitListenerConfigurationSelector extension to register a RabbitListenerTestBootstrap, but already with the higher order, so the RabbitListenerTestHarness bean is registered earlier, than RabbitListenerAnnotationBeanPostProcessor.
RabbitListenerTestSelector() - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestSelector
 
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.
RabbitOperations.OperationsCallback<T> - Interface in org.springframework.amqp.rabbit.core
Callback for using the same channel for multiple RabbitTemplate operations.
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
A callback for publisher confirmations.
RabbitTemplate.ReturnCallback - Interface in org.springframework.amqp.rabbit.core
Deprecated.
in favor of RabbitTemplate.ReturnCallback.returnedMessage(ReturnedMessage) which is easier to use with lambdas.
RabbitTemplate.ReturnsCallback - Interface in org.springframework.amqp.rabbit.core
A callback for returned messages.
RabbitTemplate.TemplateConsumer - Class in org.springframework.amqp.rabbit.core
Adds RabbitTemplate.TemplateConsumer.toString() to the DefaultConsumer.
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
 
RAW_MESSAGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
The received raw message before conversion; this header usually only appears in an ErrorMessage.
receive() - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue.
receive(String) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a specific queue.
receive(long) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message from a default queue, waiting up to the specified wait time if necessary for a message to become available.
receive(String, long) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message from a specific queue, waiting up to the specified wait time if necessary for a message to become available.
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 interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue and convert it to a Java object.
receiveAndConvert(String) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a specific queue and convert it to a Java object.
receiveAndConvert(long) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue and convert it to a Java object.
receiveAndConvert(String, long) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a specific queue and convert it to a Java object.
receiveAndConvert(ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue and convert it to a Java object.
receiveAndConvert(String, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a specific queue and convert it to a Java object.
receiveAndConvert(long, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue and convert it to a Java object.
receiveAndConvert(String, long, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a specific queue and convert it to a Java object.
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
 
receiveAndConvert(ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(String, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(long, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndConvert(String, long, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
receiveAndReply(ReceiveAndReplyCallback<R, S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the replyTo Address from MessageProperties or to default exchange and default routingKey.
receiveAndReply(String, ReceiveAndReplyCallback<R, S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from provided queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the replyTo Address from MessageProperties or to default exchange and default routingKey.
receiveAndReply(ReceiveAndReplyCallback<R, S>, String, String) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from default queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the provided exchange and routingKey.
receiveAndReply(String, ReceiveAndReplyCallback<R, S>, String, String) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from provided queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the provided exchange and routingKey.
receiveAndReply(ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from a default queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the replyTo Address from result of ReplyToAddressCallback.
receiveAndReply(String, ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Receive a message if there is one from provided queue, invoke provided ReceiveAndReplyCallback and send reply message, if the callback returns one, to the replyTo Address from result of ReplyToAddressCallback.
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
 
ReceiveAndReplyCallback<R,S> - Interface in org.springframework.amqp.core
To be used with the receive-and-reply methods of AmqpTemplate as processor for inbound object and producer for outbound object.
ReceiveAndReplyMessageCallback - Interface in org.springframework.amqp.core
Message exchanging contract of ReceiveAndReplyCallback.
RECEIVED_DELAY - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RECEIVED_DELIVERY_MODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RECEIVED_EXCHANGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RECEIVED_ROUTING_KEY - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RECEIVED_USER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.ImmediateRequeueMessageRecoverer
 
recover(Message, Throwable) - Method in interface org.springframework.amqp.rabbit.retry.MessageBatchRecoverer
 
recover(List<Message>, Throwable) - Method in interface org.springframework.amqp.rabbit.retry.MessageBatchRecoverer
Callback for message batch that was consumed but failed all retry attempts.
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.
redeclareElementsIfNecessary() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Use AmqpAdmin.initialize() to redeclare everything if necessary.
REDELIVERED - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
REF_ATTRIBUTE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
registerAllEndpoints() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.amqp.rabbit.annotation.MultiRabbitBootstrapConfiguration
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestBootstrap
 
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
Construct an instance with the default exception message.
RejectAndDontRequeueRecoverer(String) - Constructor for class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
Construct an instance with the provided exception message.
RejectAndDontRequeueRecoverer(Supplier<String>) - Constructor for class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
Construct an instance with the provided exception message supplier.
release(T) - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
releaseBatches() - Method in interface org.springframework.amqp.rabbit.batch.BatchingStrategy
Release batch(es), perhaps due to a timeout.
releaseBatches() - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
 
releaseConsumerFor(DirectReplyToMessageListenerContainer.ChannelHolder, boolean, String) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
Release the consumer associated with the channel for reuse.
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
 
RemoteInvocationAwareMessageConverterAdapter - Class in org.springframework.amqp.support.converter
A delegating adapter that unwraps RemoteInvocationResult after invoking the delegate to convert from a message.
RemoteInvocationAwareMessageConverterAdapter() - Constructor for class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
 
RemoteInvocationAwareMessageConverterAdapter(MessageConverter) - Constructor for class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
 
removeAfterReceivePostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
removeAfterReceivePostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
removeArgument(String) - Method in class org.springframework.amqp.core.AbstractDeclarable
 
removeArgument(String) - Method in interface org.springframework.amqp.core.Declarable
Remove an argument from the declarable.
removeBeforePublishPostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
removeBinding(Binding) - Method in interface org.springframework.amqp.core.AmqpAdmin
Remove a binding of a queue to an exchange.
removeBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
removeBlockedListener(BlockedListener) - Method in interface org.springframework.amqp.rabbit.connection.Connection
Remove a BlockedListener.
removeBlockedListener(BlockedListener) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
removeChannel(AutorecoveringChannel) - Static method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
Remove the channel from the set used to ensure that ClosingRecoveryListener.addRecoveryListenerIfNecessary(Channel) is idempotent.
removeConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.connection.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
 
removeDecompressor(String) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
Remove the decompressor for this encoding; content will not be decompressed even if the MessageProperties.SPRING_AUTO_DECOMPRESS header is true.
removeDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
removeDelegate(String) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
Remove the delegate for the content type.
removeExchanges(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Remove exchanges from the broker.
removeHeader(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
removeHeaders() - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.DirectMessageListenerContainer
 
removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
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.DirectMessageListenerContainer
 
removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Remove queues from this container's list of queues.
removeReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
removeShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
removeTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Removes the ConnectionFactory associated with the given lookup key and returns it.
removeTestQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Remove any test queues that were created by an BrokerRunning.isRunningWithEmptyQueues(String...) method.
removeTestQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Remove any test queues that were created by an BrokerRunningSupport.isRunningWithEmptyQueues(String...) method.
REPLY_TO - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
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
 
ReplyingMessageListener<T,R> - Interface in org.springframework.amqp.rabbit.listener.adapter
A Message Listener that returns a reply - intended for lambda use in a MessageListenerAdapter.
ReplyPostProcessor - Interface in org.springframework.amqp.rabbit.listener.adapter
A post processor for replies.
replyTimedOut(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Subclasses can implement this to be notified that a reply has timed out.
ReplyToAddressCallback<T> - Interface in org.springframework.amqp.core
To be used with the receive-and-reply methods of AmqpTemplate to determine Address for Message to send at runtime.
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
 
RepublishMessageRecovererWithConfirms - Class in org.springframework.amqp.rabbit.retry
A RepublishMessageRecoverer supporting publisher confirms and returns.
RepublishMessageRecovererWithConfirms(RabbitTemplate, CachingConnectionFactory.ConfirmType) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
Use the supplied template to publish the messsage with the provided confirm type.
RepublishMessageRecovererWithConfirms(RabbitTemplate, String, CachingConnectionFactory.ConfirmType) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
Use the supplied template to publish the messsage with the provided confirm type to the provided exchange with the default routing key.
RepublishMessageRecovererWithConfirms(RabbitTemplate, String, String, CachingConnectionFactory.ConfirmType) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
Use the supplied template to publish the messsage with the provided confirm type to the provided exchange with the provided routing key.
reset(List<ChannelProxy>, List<ChannelProxy>, Map<Channel, ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
reset() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 
resetConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Close the connection(s).
resetConnection() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
Close the connection(s).
resetConnection() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Close the connection(s).
resolveExpressionAsString(String, String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
resolveMultiRabbitAdminName(RabbitListener) - Method in class org.springframework.amqp.rabbit.annotation.MultiRabbitListenerAnnotationBeanPostProcessor
Resolves the name of the RabbitAdmin bean based on the RabbitListener, or falls back to the default RabbitAdmin name provided by MultiRabbit.
resolveParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
retrieveHeader(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
retrieveHeaderAsString(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
RetryInterceptorBuilder<B extends RetryInterceptorBuilder<B,T>,T extends 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() - Constructor for class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
 
RetryInterceptorBuilder.StatefulRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
Builder for a stateful interceptor.
RetryInterceptorBuilder.StatelessRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
Builder for a stateless interceptor.
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.
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.
RETURN_EXCHANGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RETURN_LISTENER_CORRELATION_KEY - Static variable in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Header used to determine which listener to invoke for a returned message.
RETURN_REPLY_CODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RETURN_REPLY_TEXT - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RETURN_ROUTING_KEY - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
RETURNED_MESSAGE_CORRELATION_KEY - Static variable in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Header used to locate a pending confirm to which to attach a returned message.
ReturnedMessage - Class in org.springframework.amqp.core
Returned message and its metadata.
ReturnedMessage(Message, int, String, String, String) - Constructor for class org.springframework.amqp.core.ReturnedMessage
 
returnedMessage(ReturnedMessage) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
returnedMessage(Message, int, String, String, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnCallback
Deprecated.
Returned message callback.
returnedMessage(ReturnedMessage) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnCallback
Deprecated.
Returned message callback.
returnedMessage(Message, int, String, String, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnsCallback
Deprecated.
in favor of RabbitTemplate.ReturnsCallback.returnedMessage(ReturnedMessage) which is easier to use with lambdas.
returnedMessage(ReturnedMessage) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnsCallback
Returned message callback.
revertLevels(String, JUnitUtils.LevelsContainer) - Static method in class org.springframework.amqp.rabbit.junit.JUnitUtils
 
revoke(Channel) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
When called, this listener should remove all references to the channel - it will no longer be invoked by the channel.
revoke(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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.listener.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.connection.PublisherCallbackChannelImpl
 
run(Runnable) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Runnable binding to the default ConnectionFactory and finally unbinding it.
run(String, Runnable) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Runnable binding the given ConnectionFactory and finally unbinding it.
run() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.EventSender
 
run() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.EventSender
 
RUN_LONG_INTEGRATION_TESTS - Static variable in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
 

S

selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurationSelector
 
selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestSelector
 
send(Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
Send a message to a default exchange with a default routing key.
send(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
Send a message to a default exchange with a specific routing key.
send(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
Send a message to a specific exchange with a specific routing key.
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(String, Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Send a message to the default exchange with a specific routing key.
send(String, String, Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Send a message to a specific exchange with a specific routing key.
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, Message, CorrelationData) - 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 interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern.
sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern.
sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern.
sendAndReceive(Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Send a message to the default exchange with the default routing key.
sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Send a message to the default exchange with the supplied routing key.
sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
Send a message to the supplied exchange and routing key.
sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
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
 
sendEvent(AmqpAppender.Event, Map<?, ?>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
sendResponse(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Send the given response message to the given destination.
SendRetryContextAccessor - Class in org.springframework.amqp.support
Type safe accessor for retried message sending.
sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
SerializationUtils - Class in org.springframework.amqp.utils
Static utility to help with serialization.
serialize(Object) - Static method in class org.springframework.amqp.utils.SerializationUtils
Serialize the object provided.
SerializerMessageConverter - Class in org.springframework.amqp.support.converter
Implementation of MessageConverter that can work with Strings or native objects of any kind via the Serializer and Deserializer abstractions in Spring.
SerializerMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SerializerMessageConverter
 
setAbbreviation(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAckMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Flag controlling the behaviour of the container with respect to message acknowledgement.
setAckTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
An approximate timeout; when messagesPerAck is greater than 1, and this time elapses since the last ack, the pending acks will be sent either when the next message arrives, or a short time later if no additional messages arrive.
setAckTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
An approximate timeout; when messagesPerAck is greater than 1, and this time elapses since the last ack, the pending acks will be sent either when the next message arrives, or a short time later if no additional messages arrive.
setActualName(String) - Method in class org.springframework.amqp.core.Queue
Set the name from the DeclareOk.
setAddMdcAsHeaders(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setAddMdcAsHeaders(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAddresses(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set addresses for clustering.
setAddresses(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setAddresses(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setAddressResolver(AddressResolver) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
setAddressShuffleMode(AbstractConnectionFactory.AddressShuffleMode) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set the mode for shuffling addresses.
setAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the AmqpAdmin instance to use.
setAdminPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Set the password for the management REST API connection default "guest".
setAdminPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set the password for the management REST API connection default "guest".
setAdminsThatShouldDeclare(Object...) - Method in class org.springframework.amqp.core.AbstractDeclarable
 
setAdminsThatShouldDeclare(Object...) - Method in interface org.springframework.amqp.core.Declarable
The AmqpAdmins that should declare this object; default is all admins.
setAdminsThatShouldDeclare(AmqpAdmin...) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setAdminUri(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Set the uri for the REST API.
setAdminUri(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set the uri for the REST API.
setAdminUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Set the user for the management REST API connection default "guest".
setAdminUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set the user for the management REST API connection default "guest".
setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Public setter for the Advice to apply to listener executions.
setAfterAckCallback(Consumer<Channel>) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Set a callback to be invoked after the ack/nack has been handled.
setAfterAckCallback(Consumer<Channel>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set post processors which will be applied after the Message is received.
setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setAllowedListPatterns(List<String>) - Method in class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
Set simple patterns for allowable packages/classes for deserialization.
setAlwaysConvertToInferredType(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
When false (default), fall back to type id headers if the type (or contents of a container type) is abstract.
setAlwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to true to always requeue on transaction rollback with an external TransactionManager.
setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the AmqpAdmin, used to declare any auto-delete queues, bindings etc when the container is started.
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.
setAmqpTemplate(AmqpTemplate) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
The AMQP template to be used for sending messages and receiving results.
setAmqpTemplate(AmqpTemplate) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
The AMQP template to use for sending the return value.
setAppId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setAppId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setAppIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
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
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
setApplicationId(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setApplicationId(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setAssumeSupportedContentType(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
By default the supported content type is assumed when there is no contentType property or it is set to the default ('application/octet-stream').
setAsync(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to true to automatically declare elements (queues, exchanges, bindings) in the application context during container start().
setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
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.config.ListenerContainerFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
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.
setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Override the default autoStartup property.
setAutoStartup(boolean) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
Set auto startup.
setBackOffExecution(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the BackOffExecution to use for the recovery in the SimpleMessageListenerContainer.
setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set a BatchingStrategy to use when debatching messages.
setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set a batching strategy to use when de-batching messages.
setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setBatchingStrategy(BatchingStrategy) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Set a BatchingStrategy to use when debatching messages.
setBatchListener(boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set to true to receive a list of debatched messages that were created by a BatchingRabbitTemplate.
setBatchListener(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set to true if this endpoint should create a batch listener.
setBatchListener(boolean) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
Called by the container factory with the factory's batchListener property.
setBatchSize(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
This property has several functions.
setBatchSize(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
 
setBatchSize(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
This property has several functions.
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
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
 
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
setBeanName(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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.
setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set post processors that will be applied before sending replies; added to each message listener adapter.
setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set post processors that will be applied before sending replies.
setBlockingQueueFactory(BlockingQueueFactory<AmqpAppender.Event>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setBufferSize(int) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setCause(String) - Method in class org.springframework.amqp.rabbit.connection.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
 
setChannelRpcTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setChannelTransacted(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.annotation.RabbitListenerAnnotationBeanPostProcessor
Set a charset for byte[] to String method argument conversion.
setCharset(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setCharset(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setClassMapper(ClassMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
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.AbstractConnectionFactory
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).
setClusterId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setClusterId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setClusterIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setCodebaseUrl(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Deprecated.
due to deprecation of CodebaseAwareObjectInputStream.
setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the concurrency of this endpoint; usually overrides any concurrency settings on the container factory.
setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Specify concurrency limits via a "lower-upper" String, e.g.
setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setConfiguration(Configuration) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setConfirmCallback(RabbitTemplate.ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setConfirmTimeout(long) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
Set the confirm timeout; default 10 seconds.
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.config.ListenerContainerFactoryBean
 
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.core.RabbitTemplate
 
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
 
setConnectionName(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setConnectionName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Set a name for the connection which will appear on the RabbitMQ Admin UI.
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(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setConsumeDelay(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the consumeDelay - a time to wait before consuming in ms.
setConsumeDelay(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the consumeDelay - a time to wait before consuming in ms.
setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set consumer arguments.
setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
Set to true to present a list of messages based on the ListenerContainerFactoryBean.setBatchSize(int), if the container and listener support it.
setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
Set to true to present a list of messages based on the SimpleRabbitListenerContainerFactory.setBatchSize(Integer), if the listener supports it.
setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set to true to present a list of messages based on the SimpleMessageListenerContainer.setBatchSize(int), if the listener supports it.
setConsumerQueue(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setConsumersPerQueue(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
Each queue runs in its own consumer; set this property to create multiple consumers for each queue.
setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Each queue runs in its own consumer; set this property to create multiple consumers for each queue.
setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
setConsumerStartTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
When starting a consumer, if this time (ms) elapses before the consumer starts, an error log is written; one possible cause would be if the taskExecutor has insufficient threads to support the container concurrency.
setConsumerTag(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the implementation of ConsumerTagStrategy to generate consumer tags.
setContainerCustomizer(ContainerCustomizer<C>) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set a ContainerCustomizer that is invoked after a container is created and configured to enable further customization of the container.
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.core.MessageBuilderSupport
 
setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setContentEncodingIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setContentLength(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setContentLength(long) - Method in class org.springframework.amqp.core.MessageProperties
 
setContentLengthIfAbsent(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setContentType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setContentType(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setContentType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setContentType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setContentType(String) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Set the contentType to be used by this message converter.
setContentTypeIfAbsentOrDefault(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setConverterWinsContentType(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set whether the content type set by a converter prevails or not.
setConverterWinsContentType(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set whether the content type set by a converter prevails or not.
setCopyProperties(boolean) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Flag to indicate if MessageProperties should be used as is or cloned for new message after compression.
setCorrelationDataPostProcessor(CorrelationDataPostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set a CorrelationDataPostProcessor to be invoked before publishing a message.
setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageProperties
Set the correlation id.
setCorrelationIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.
setCreateMessageIds(boolean) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
Flag to indicate that new messages should have unique identifiers added to their properties before sending.
setCredentialsProvider(CredentialsProvider) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set a credentials provider (e.g.
setCredentialsRefreshService(CredentialsRefreshService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set a refresh service.
setCustomMethodArgumentResolvers(HandlerMethodArgumentResolver...) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Add custom methods arguments resolvers to RabbitListenerAnnotationBeanPostProcessor Default empty list.
setDeBatchingEnabled(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Determine whether or not the container should de-batch batched messages (true) or call the listener with the batch (false).
setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.config.ListenerContainerFactoryBean
 
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.log4j2.AmqpAppender.Builder
 
setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setDecompressors(Map<String, MessagePostProcessor>) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
Replace all the decompressors.
setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Specify the default charset to use when converting to or from text-based Message body content.
setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
Specify the default charset to use when converting to or from text-based Message body content.
setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Specify the default charset to use when converting to or from text-based Message body content.
setDefaultConsumer(Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
setDefaultEncoding(String) - Static method in class org.springframework.amqp.core.Message
Set the encoding to use in Message.toString() when converting the body if there is no contentEncoding message property present.
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.
setDefaultMapClass(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
Set the type of Map to use.
setDefaultReceiveQueue(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.
setDefaultRequeueRejected(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the default behavior when a message is rejected, for example because the listener threw an exception.
setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set to the value of this listener's container equivalent property.
setDefaultTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
Specify the default target ConnectionFactory, if any.
setDefaultType(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
The type returned by DefaultClassMapper.toClass(MessageProperties) if no type information is found in the message properties.
setDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
Set the x-delay header.
setDelayed(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
Set the delayed flag.
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
 
setDelegates(Map<String, MessageConverter>) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
 
setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
 
setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
Specify a MessageDeliveryMode to set into the message to republish if the message doesn't have it already.
setDeliveryModeIfAbsentOrDefault(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setDeliveryTag(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setDeliveryTag(long) - Method in class org.springframework.amqp.core.MessageProperties
 
setDeliveryTagIfAbsent(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setDeserializer(Deserializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
The deserializer to use for converting from message body to Java object.
setDestinationExchange(Exchange) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setDestinationQueue(Queue) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setDiscardFatalsWithXDeath(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Set to false to disable the (now) default behavior of logging and discarding messages that cause fatal exceptions and have an `x-death` header; which usually means that the message has been republished after previously being sent to a DLQ.
setDurable(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
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.
setEnableHostnameVerification(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Enable server hostname verification for TLS connections.
setEncoder(Encoder<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setEncoding(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
The encoding to use when 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.
setEncodingDelimiter(String) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Set a delimiter to be added between the compression type and the original encoding, if any.
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.MultiRabbitBootstrapConfiguration
 
setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
 
setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
 
setEnvironmentVariableOverrides(Map<String, String>) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Set environment variable overrides for host, port etc.
setEnvironmentVariableOverrides(Map<String, String>) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set environment variable overrides for host, port etc.
setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setErrorHandler(RabbitListenerErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Set the RabbitListenerErrorHandler to invoke if the listener method throws an exception.
setErrorHandlerLoggerName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the name (category) of the logger used to log exceptions thrown by the error handler.
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.
setExchange(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setExchangeName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setExchangeType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setExchangeType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to true for an exclusive consumer.
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.DirectMessageListenerContainer
Set to true for an exclusive consumer - if true, the consumers per queue must be 1.
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.config.ListenerContainerFactoryBean
 
setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
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.
setExpiration(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setExpiration(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setExpirationIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setExplicitDeclarationsOnly(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Set to true to only declare Declarable beans that are explicitly configured to be declared by this admin.
setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.config.AbstractRabbitListenerContainerFactory
 
setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the interval between passive queue declaration attempts in milliseconds.
setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the interval between passive queue declaration attempts in milliseconds.
setFilter(Filter) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setFinalRetryForMessageWithNoId(boolean) - Method in class org.springframework.amqp.core.MessageProperties
 
setForceCloseChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to true to force close the channel if the consumer threads don't respond to a shutdown.
setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Apply prefetch to the entire channel.
setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
Apply prefetch to the entire channel.
setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Apply prefetchCount to the entire channel.
setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Apply prefetch to the entire channel.
setGroup(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the group for the corresponding listener container.
setHandlerAdapter(HandlerAdapter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
Set the HandlerAdapter to use to invoke the method processing an incoming Message.
setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageProperties
 
setHeaderIfAbsent(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
Set the AmqpHeaderMapper implementation to use to map the standard AMQP headers.
setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
Set the AmqpHeaderMapper to use to map AMQP headers to and from standard message 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.log4j2.AmqpAppender.Builder
 
setHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setHostName(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
 
setHostName(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
setId(String) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Set the correlation id.
setId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
Set a map of type Ids (in the "__TypeId__" header) to classes.
setIdleEventInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
How often to publish idle container events.
setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
How often to emit ListenerContainerIdleEvents in milliseconds.
setIgnoreContentType(boolean) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
Flag to signal that the content type should be ignored and the deserializer used irrespective if it is a text message.
setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
Set to true to ignore exceptions such as mismatched properties when declaring.
setIgnoreDeclarationExceptions(Boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
setIgnoreExceptions(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setIncludeCallerData(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
If true, the caller data will be available in the target AMQP message.
setInferredArgumentType(Type) - Method in class org.springframework.amqp.core.MessageProperties
Set the inferred target argument type when using a method-level @RabbitListener.
setInternal(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
Set the internal flag.
setjavaLangErrorHandler(AbstractMessageListenerContainer.JavaLangErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Provide a JavaLangErrorHandler implementation; by default, System.exit(99) is called.
setJavaTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
setKeyStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store resource (e.g.
setKeyStore(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setKeyStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setKeyStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the algorithm used when creating the key store, default SunX509.
setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store pass phrase - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
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).
setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setLastInBatch(boolean) - Method in class org.springframework.amqp.core.MessageProperties
Set to true to indicate these properties are for the last message in a batch.
setLayout(Layout<? extends Serializable>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setLayout(Layout<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setLeaderLocator(String) - Method in class org.springframework.amqp.core.Queue
Set the leader locator strategy argument for this queue.
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.
setLevel(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
Set the deflater compression level.
setListenerId(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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
Set the mandatory flag when sending messages; only applies if a returnCallback had been provided.
setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setMandatoryPublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
setMarshaller(Marshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Set the Marshaller to be used by this message converter.
setMasterLocator(String) - Method in class org.springframework.amqp.core.Queue
Deprecated.
setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.log4j2.AmqpAppender.Builder
 
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.AbstractRabbitListenerEndpoint
 
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.
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
setMessageConverter(MessageConverter) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
The preferred way for a container factory to pass a message converter to the endpoint's adapter.
setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
Set the message converter for this remote service.
setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageProperties
Set the message count.
setMessageCountIfAbsent(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.
setMessageId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setMessageId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setMessageIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setMessageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.AbstractMessageListenerContainer
Set the MessagePropertiesConverter for this listener container.
setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
setMessagesPerAck(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
Set the number of messages to receive before acknowledging (success).
setMessagesPerAck(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Set the number of messages to receive before acknowledging (success).
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
 
setMicrometerEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to false to disable micrometer listener timers.
setMicrometerTags(Map<String, String>) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set additional tags for the Micrometer listener timers.
setMismatchedQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Prevent the container from starting if any of the queues defined in the context have mismatched arguments (TTL etc).
setMissingQueuePublisher(Consumer<String>) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Set the publisher for a missing queue event.
setMissingQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
If all of the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
If all of the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
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.
setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
Set how often to run a task to check for failed consumers and idle containers.
setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Set how often to run a task to check for failed consumers and idle containers.
setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
setName(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setNewMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
setNioParams(NioParams) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setNoLocal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setNoLocal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set to true for an no-local consumer.
setNoLocalReplyConsumer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set to true for a no-local consumer.
setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
Set the order.
setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
Set the order.
setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
Set the order.
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.junit.BrokerRunning
Set the password for the amqp connection default "guest".
setPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set the password for the amqp connection default "guest".
setPassword(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setPassword(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setPayloadConverter(MessageConverter) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
Set the MessageConverter to use to convert the payload.
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.config.ListenerContainerFactoryBean
 
setPhase(int) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
setPhase(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Specify the phase in which this container should be started and stopped.
setPhysicalCloseRequired(Channel, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Sets a ThreadLocal indicating the channel MUST be physically closed.
setPoolConfigurer(BiConsumer<GenericObjectPool<Channel>, Boolean>) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
Add a consumer to configure the object pool.
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.junit.BrokerRunning
 
setPort(int) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
 
setPort(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setPort(Integer) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setPossibleAuthenticationFailureFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setPossibleAuthenticationFailureFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setPrefetchCount(Integer) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Tell the broker how many messages to send to each consumer in a single request.
setPriority(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setPriority(Integer) - Method in class org.springframework.amqp.core.MessageProperties
 
setPriority(Integer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the priority of this endpoint.
setPriorityIfAbsentOrDefault(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setPublisherChannelFactory(PublisherCallbackChannelFactory) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Set the factory to use to create PublisherCallbackChannel instances.
setPublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
setPublisherConfirmType(CachingConnectionFactory.ConfirmType) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Set the confirm type to use; default CachingConnectionFactory.ConfirmType.NONE.
setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Set a custom publisher connection factory; the type does not need to be the same as this factory.
setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
 
setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
 
setPublisherReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
setPublishSequenceNumber(long) - Method in class org.springframework.amqp.core.MessageProperties
Set the publish sequence number, if publisher confirms are enabled; set by the template.
setPurgeAfterEach(boolean) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Purge the test queues after each test (JUnit 5).
setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.DirectMessageListenerContainer
 
setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
 
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.config.ListenerContainerFactoryBean
 
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.
setRabbitAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setRabbitOperations(RabbitOperations) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
Set the RabbitOperations for the gateway.
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.
setReceivedDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
When a delayed message exchange is used the x-delay header on a received message contains the delay.
setReceivedDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
 
setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setReceivedExchangeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setReceivedRoutingKeyIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReceivedUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
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.ListenerContainerFactoryBean
 
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.AbstractRabbitListenerContainerFactory
 
setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
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.
setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set a RecoveryCallback to invoke when retries are exhausted.
setRecoveryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
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.
setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageProperties
 
setRedeliveredIfAbsent(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.
setRejectManual(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
Set to false to NOT reject a fatal message when MANUAL ack mode is being used.
setRemoteInvocationFactory(RemoteInvocationFactory) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
Set the RemoteInvocationFactory to use for this accessor.
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 https://www.rabbitmq.com/direct-reply-to.html
setReplyContentType(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set the reply content type.
setReplyContentType(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set the reply content type.
setReplyErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
When using a direct reply-to container for request/reply operations, set an error handler to be invoked when a reply delivery fails (e.g.
setReplyPostProcessor(ReplyPostProcessor) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Set a ReplyPostProcessor to post process a response message before it is sent.
setReplyPostProcessor(ReplyPostProcessor) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set a ReplyPostProcessor to post process a response message before it is sent.
setReplyRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
Set a RecoveryCallback to invoke when retries are exhausted.
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.
setReplyTo(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReplyTo(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageProperties
 
setReplyToAddressIfAbsent(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setReplyToIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.
setResourceLoader(ResourceLoader) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the resource loader; used to resolve the key store and trust store Resources to input streams.
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.config.ListenerContainerFactoryBean
 
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.config.AbstractRabbitListenerContainerFactory
Set a RetryTemplate to use when sending replies; added to each message listener adapter.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Set a retry template for auto declarations.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add a RetryTemplate which will be used for all rabbit operations.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Set a RetryTemplate to use when sending replies.
setReturnCallback(RabbitTemplate.ReturnCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
setReturned(ReturnedMessage) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
Set the returned message and metadata.
setReturned(boolean) - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
Indicate that a returned message has been received.
setReturnedMessage(Message) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
setReturnExceptions(boolean) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
Set whether exceptions thrown by the listener should be returned to the sender using the normal replyTo/@SendTo semantics.
setReturnsCallback(RabbitTemplate.ReturnsCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
setReturnType(ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
 
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.
setRoutingKey(String) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
The routing key to send calls to the service with.
setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setSaslConfig(SaslConfig) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setSaslConfig(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setSaslConfig(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Set the SaslConfig.
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.log4j2.AmqpAppender.Builder
 
setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setSerializer(Serializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
The serializer to use for converting Java objects to message bodies.
setSharedExecutor(ExecutorService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setShouldDeclare(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
Whether or not this object should be automatically declared by any AmqpAdmin.
setShouldDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
setShuffleAddresses(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
The time to wait for workers in milliseconds after the container is stopped.
setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
Enable simple publisher confirms.
setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Enable simple publisher confirms.
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.
setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setSslPropertiesLocation(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
When RabbitConnectionFactoryBean.setUseSSL(boolean) is true, the SSL properties to use (optional).
setSslPropertiesLocation(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setSslPropertiesLocation(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setStatefulRetryFatalWithNullMessageId(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set whether a message with a null messageId is fatal for the consumer when using stateful retry.
setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
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.
setTargetBean(Object) - Method in class org.springframework.amqp.core.MessageProperties
Set the target bean when using @RabbitListener.
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.
setTargetMethod(Method) - Method in class org.springframework.amqp.core.MessageProperties
Set the target method when using a @RabbitListener.
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Set a task executor to use for async operations.
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set a task executor to use when using a DirectReplyToMessageListenerContainer.
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set a task executor for the container - used to create the consumers not at runtime.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
Override the default task executor.
setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Set the task scheduler to expire timed out futures.
setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
Set the task scheduler to use for the task that monitors idle containers and failed consumers.
setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
Set the task scheduler to use for the task that monitors idle containers and failed consumers.
setThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageProperties
 
setTimestampIfAbsent(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.config.ListenerContainerFactoryBean
 
setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the transaction attribute to use when using an external transaction manager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set the transaction manager to use.
setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
Specify a set of packages to trust during deserialization.
setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
Specify a set of packages to trust during deserialization.
setTrustStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the key store resource (e.g.
setTrustStore(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setTrustStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setTrustStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the algorithm used when creating the trust store, default SunX509.
setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Set the trust store pass phrase - overrides the property in RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource).
setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
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).
setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setType(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setType(ListenerContainerFactoryBean.Type) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
setTypeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Set the precedence for evaluating type information in message properties.
setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
Set the precedence for evaluating type information in message properties.
setUnmarshaller(Unmarshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Set the Unmarshaller to be used by this message converter.
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(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
setupMessageListener(MessageListener) - 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
 
setUri(URI) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setUri(URI) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
setUseChannelForCorrelation(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
When using direct reply-to, set this to true to avoid the server needing to send the correlation id in a reply header.
setUseDirectReplyToContainer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set whether or not to use a DirectReplyToMessageListenerContainer when direct reply-to is available and being used.
setUseNio(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not the factory should be configured to use Java NIO.
setUseProjectionForInterfaces(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Set to true to use Spring Data projection to create the object if the inferred parameter type is an interface.
setUsePublisherConnection(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
To avoid deadlocked connections, it is generally recommended to use a separate connection for publishers and consumers (except when a publisher is participating in a consumer transaction).
setUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
Set the user for the amqp connection default "guest".
setUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Set the user for the amqp connection default "guest".
setUser(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setUserCorrelationId(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Set to true to use correlation id provided by the message instead of generating the correlation id for request/reply scenarios.
setUserId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
setUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
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.
setUserIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
 
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.logback.AmqpAppender
 
setUseSSL(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
Whether or not the factory should be configured to use SSL.
setUseSsl(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setUseSsl(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
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).
setValidator(Validator) - Method in class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
Set a payload validator.
setValidator(Validator) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
Set the validator to use if the default message handler factory is used.
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.
setVerifyHostname(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
 
setVerifyHostname(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Enable server hostname verification for TLS connections.
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.log4j2.AmqpAppender.Builder
 
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.
shouldDeclare() - Method in class org.springframework.amqp.core.AbstractDeclarable
 
shouldDeclare() - Method in interface org.springframework.amqp.core.Declarable
Whether or not this object should be automatically declared by any AmqpAdmin.
shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.QueueParser
 
shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.QueueParser
 
shouldRequeue(boolean, Throwable, Log) - Static method in class org.springframework.amqp.rabbit.listener.support.ContainerUtils
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 or if there is an ImmediateRequeueAmqpException 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.
ShutDownChannelListener - Interface in org.springframework.amqp.rabbit.connection
Functional sub interface enabling a lambda for the onShutDown method.
shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
SimpleAmqpHeaderMapper - Class in org.springframework.amqp.support
Simple implementation of AmqpHeaderMapper.
SimpleAmqpHeaderMapper() - Constructor for class org.springframework.amqp.support.SimpleAmqpHeaderMapper
 
SimpleBatchingStrategy - Class in org.springframework.amqp.rabbit.batch
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.batch.SimpleBatchingStrategy
 
SimpleConnection - Class in org.springframework.amqp.rabbit.connection
Simply a Connection.
SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
 
SimpleMessageConverter - Class in org.springframework.amqp.support.converter
Implementation of MessageConverter that can work with Strings, Serializable instances, or byte arrays.
SimpleMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SimpleMessageConverter
 
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).
SimplePropertyValueConnectionNameStrategy - Class in org.springframework.amqp.rabbit.connection
A ConnectionNameStrategy that returns the value of a (required) property.
SimplePropertyValueConnectionNameStrategy(String) - Constructor for class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
 
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
 
singleActiveConsumer() - Method in class org.springframework.amqp.core.QueueBuilder
Set the 'x-single-active-consumer' queue argument.
SmartMessageConverter - Interface in org.springframework.amqp.support.converter
An extended MessageConverter SPI with conversion hint support.
sort(Collection<MessagePostProcessor>) - Static method in class org.springframework.amqp.support.postprocessor.MessagePostProcessorUtils
 
SPRING_AUTO_DECOMPRESS - Static variable in class org.springframework.amqp.core.MessageProperties
 
SPRING_BATCH_FORMAT - Static variable in class org.springframework.amqp.core.MessageProperties
 
SPRING_REPLY_CORRELATION - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
SPRING_REPLY_TO_STACK - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
SpringRabbitTest - Annotation Type in org.springframework.amqp.rabbit.test.context
Adds infrastructure beans to a Spring test context; do not use with Spring Boot since it has its own auto configuration mechanism.
SpringRabbitTest.ContainerType - Enum in org.springframework.amqp.rabbit.test.context
Container type.
start() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
start() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
start() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
start() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
 
start() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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
 
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() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
stop(Runnable) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
 
stop() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
stop() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
 
stop() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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
 
stringToSaslConfig(String, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Convert a String value to a SaslConfig.
supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
 
suppressDeclaration() - Method in class org.springframework.amqp.core.ExchangeBuilder
Switch to disable declaration of the exchange by any admin.
switchContext(Object) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Acquire ownership of another thread's channel(s) after that thread called ThreadChannelConnectionFactory.prepareSwitchContext().
SYSTEM - Static variable in class org.springframework.amqp.core.ExchangeTypes
System exchange.

T

TemplateConsumer(Channel) - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate.TemplateConsumer
 
test() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
Check connectivity to the broker and create any queues.
TestRabbitTemplate - Class in org.springframework.amqp.rabbit.test
A RabbitTemplate that invokes @RabbitListener s directly.
TestRabbitTemplate(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
TestUtils - Class in org.springframework.amqp.utils.test
See Spring Integration TestUtils.
THREAD_NAME - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
Key name for the thread name in the message properties.
THREAD_NAME - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
Key name for the thread name in the message properties.
ThreadChannelConnectionFactory - Class in org.springframework.amqp.rabbit.connection
A very simple connection factory that caches a channel per thread.
ThreadChannelConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
Construct an instance.
TIMESTAMP - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
to(FanoutExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(HeadersExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(DirectExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(TopicExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(Exchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
toClass(MessageProperties) - Method in interface org.springframework.amqp.support.converter.ClassMapper
 
toClass(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
 
toClass(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
toHeaders(MessageProperties) - Method in class org.springframework.amqp.support.SimpleAmqpHeaderMapper
 
toInt(MessageDeliveryMode) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
 
toJavaType(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
toJavaType(MessageProperties) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
Determine the type from the message properties.
toMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
 
toMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
 
toMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
 
toMessage(Object, MessageProperties) - Method in interface org.springframework.amqp.support.converter.MessageConverter
Convert a Java object to a Message.
toMessage(Object, MessageProperties, Type) - Method in interface org.springframework.amqp.support.converter.MessageConverter
Convert a Java object to a Message.
toMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
 
toMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
 
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.BatchMessagingMessageListenerAdapter
 
toMessagingMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
TOPIC - Static variable in class org.springframework.amqp.core.ExchangeTypes
Topic exchange.
topicExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
Return a TopicExchange builder.
TopicExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a topic exchange.
TopicExchange(String) - Constructor for class org.springframework.amqp.core.TopicExchange
 
TopicExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.TopicExchange
 
TopicExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.TopicExchange
 
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.core.AbstractExchange
 
toString() - Method in class org.springframework.amqp.core.Address
 
toString() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
 
toString() - Method in exception org.springframework.amqp.core.AmqpReplyTimeoutException
 
toString() - Method in class org.springframework.amqp.core.Binding
 
toString() - Method in class org.springframework.amqp.core.Declarables
 
toString() - Method in class org.springframework.amqp.core.Message
 
toString() - Method in class org.springframework.amqp.core.MessageProperties
 
toString() - Method in class org.springframework.amqp.core.Queue
 
toString() - Method in class org.springframework.amqp.core.QueueInformation
 
toString() - Method in class org.springframework.amqp.core.ReturnedMessage
 
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.CorrelationData.Confirm
 
toString() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
 
toString() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
 
toString() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
toString() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
toString() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
 
toString() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
 
toString() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate.TemplateConsumer
 
toString() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
 
toString() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
 
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.ConsumeOkEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer.ChannelHolder
 
toString() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerTerminatedEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.MissingQueueEvent
 
toString() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
TRUE - Static variable in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
ttl(int) - Method in class org.springframework.amqp.core.QueueBuilder
Set the message time-to-live after which it will be discarded, or routed to the dead-letter-exchange, if so configured.
txCommit() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
txRollback() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
txSelect() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
type - Variable in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
TYPE - Static variable in class org.springframework.amqp.support.AmqpHeaders
 

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.
UncategorizedAmqpException - Exception in org.springframework.amqp
A "catch-all" exception type within the AmqpException hierarchy when no more specific cause is known.
UncategorizedAmqpException(Throwable) - Constructor for exception org.springframework.amqp.UncategorizedAmqpException
 
UncategorizedAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.UncategorizedAmqpException
 
unRegisterConsumerChannel() - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
See registerConsumerChannel.
unregisterListenerContainer(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
Remove a listener container from the registry.
UnzipPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a ZipInputStream to decompress the message body.
UnzipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.UnzipPostProcessor
 
UnzipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.UnzipPostProcessor
 
updateClientConnectionProperties(AbstractConnectionFactory, String) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryConfigurationUtils
Parse the properties key:value[,key:value]... and add them to the underlying connection factory 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.
updateLastReceive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
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).
useDirectReplyTo() - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
 
USER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
 
UUIDNamingStrategy - Class in org.springframework.amqp.core
Generates names using UUID.randomUUID().
UUIDNamingStrategy() - Constructor for class org.springframework.amqp.core.UUIDNamingStrategy
 

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.core.AcknowledgeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.Binding.DestinationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.QueueBuilder.LeaderLocator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.QueueBuilder.MasterLocator
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.QueueBuilder.Overflow
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.rabbit.connection.AbstractConnectionFactory.AddressShuffleMode
Returns the enum constant of this type with the specified name.
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.connection.CachingConnectionFactory.ConfirmType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.rabbit.test.context.SpringRabbitTest.ContainerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.support.converter.Jackson2JavaTypeMapper.TypePrecedence
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.amqp.core.AcknowledgeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.Binding.DestinationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.QueueBuilder.LeaderLocator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.QueueBuilder.MasterLocator
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.QueueBuilder.Overflow
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.config.ListenerContainerFactoryBean.Type
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.connection.AbstractConnectionFactory.AddressShuffleMode
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.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.connection.CachingConnectionFactory.ConfirmType
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.test.context.SpringRabbitTest.ContainerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.support.converter.Jackson2JavaTypeMapper.TypePrecedence
Returns an array containing the constants of this enum type, in the order they are declared.
verifyType(String, Object) - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 

W

waitForConfirms() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
waitForConfirms(long) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
waitForConfirms(long) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Delegate to the underlying dedicated channel to wait for confirms.
waitForConfirms(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
waitForConfirmsOrDie() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie(long) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie(long) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Delegate to the underlying dedicated channel to wait for confirms.
waitForConfirmsOrDie(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
waitForReturnIfNeeded() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
Return true if a return has been passed to the listener or if no return has been received.
where(String) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAll(String...) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAll(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAny(String...) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAny(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.GenericExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.GenericExchangeRoutingKeyConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.TopicExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.TopicExchangeRoutingKeyConfigurer
 
withArgument(String, Object) - Method in class org.springframework.amqp.core.ExchangeBuilder
Add an argument.
withArgument(String, Object) - Method in class org.springframework.amqp.core.QueueBuilder
The final queue will contain argument used to declare a queue.
withArguments(Map<String, Object>) - Method in class org.springframework.amqp.core.ExchangeBuilder
Add the arguments.
withArguments(Map<String, Object>) - Method in class org.springframework.amqp.core.QueueBuilder
The final queue will contain arguments used to declare a queue.
withBody(byte[]) - Static method in class org.springframework.amqp.core.MessageBuilder
The final message body will be a direct reference to 'body'.
withBody(byte[], int, int) - Static method in class org.springframework.amqp.core.MessageBuilder
The final message body will be a new array containing the byte range from 'body'.
withClonedBody(byte[]) - Static method in class org.springframework.amqp.core.MessageBuilder
The final message body will be a copy of 'body' in a new array.
withQueueName() - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
wrap(Message<?>) - Static method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
Create a AmqpMessageHeaderAccessor from the headers of an existing message.
WrappedTransactionException(Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.WrappedTransactionException
 
wrapToListenerExecutionFailedExceptionIfNeeded(Exception, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 

X

X_DELAY - Static variable in class org.springframework.amqp.core.MessageProperties
 
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
 
X_QUEUE_LEADER_LOCATOR - Static variable in class org.springframework.amqp.core.Queue
Argument key for the queue leader locator.
X_QUEUE_MASTER_LOCATOR - Static variable in class org.springframework.amqp.core.Queue
Deprecated.

Z

ZipPostProcessor - Class in org.springframework.amqp.support.postprocessor
A post processor that uses a ZipOutputStream to compress the message body.
ZipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.ZipPostProcessor
 
ZipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.ZipPostProcessor
 

_

_this() - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
 
_this() - Method in class org.springframework.amqp.utils.MapBuilder
 
A B C D E F G H I J L M N O P Q R S T U V W X Z _ 
Skip navigation links
Spring AMQP