A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
All Classes All Packages

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
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, 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.
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.
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(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.
acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.amqp.utils.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null.
ackMode() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Override the container factory AcknowledgeMode property.
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
Deprecated.
toString() no longer deserializes the body.
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(ConfirmCallback, ConfirmCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
addConfirmListener(ConfirmListener) - 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(String, MessageConverter) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
Add a delegate converter for the content type.
addDelegate(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
addDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
addDeliveryTag(Channel, long) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
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(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Add this template as a confirms listener for the provided channel.
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.
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
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(ReturnCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
Added to the 5.0.x client.
addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
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
 
admin() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Reference to a AmqpAdmin.
admins() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
Return a list of admin bean names that should declare this component.
admins() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
Return a list of admin bean names that should declare this component.
admins() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
Return a list of admin bean names that should declare this component.
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
Deprecated.
 
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 - 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(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.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
Deprecated.
will be removed in 3.0.0.
AmqpClientInterceptor() - Constructor for class org.springframework.amqp.remoting.client.AmqpClientInterceptor
Deprecated.
 
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(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpException
 
AmqpException(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
Deprecated.
will be removed in 3.0.0.
AmqpInvokerServiceExporter() - Constructor for class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
Deprecated.
 
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
Deprecated.
will be removed in 3.0.0.
AmqpProxyFactoryBean() - Constructor for class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
Deprecated.
 
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(String, boolean, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied arguments.
AmqpRejectAndDontRequeueException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied arguments.
AmqpRejectAndDontRequeueException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
Construct an instance with the supplied argument.
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(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
 
AmqpResourceNotAvailableException(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) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
 
AmqpTimeoutException(String, Throwable) - 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(ILoggingEvent) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
append(LogEvent) - Method in class org.springframework.amqp.rabbit.log4j2.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, Description) - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
 
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.amqp.rabbit.junit.LogLevelAdjuster
 
apply(InvocationOnMock, T) - Method in interface org.springframework.amqp.rabbit.test.mockito.LambdaAnswer.ValueToReturn
 
applyCommonOverrides(RabbitListenerEndpoint, C) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
 
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
 
arguments() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
arguments() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
 
arguments() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
 
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) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
Construct an instance using the provided arguments.
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) - 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.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
 
AUTO - org.springframework.amqp.core.AcknowledgeMode
Auto - the container will issue the ack/nack based on whether the listener returns normally, or throws an exception.
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.
autoDelete() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
autoDelete() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
Specifies if this queue should be auto deleted when not used.
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.
autoStartup() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Set to true or false, to override the default setting in the container factory.
await(int) - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
Wait for the latch to count down.
await(long, TimeUnit) - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
 

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.
BASE_PACKAGE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
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.
BaseRabbitListenerContainerFactory<C extends MessageListenerContainer> - Class in org.springframework.amqp.rabbit.config
Base abstract class for listener container factories.
BaseRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
 
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() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicCancel(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
basicCancel(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
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, CancelCallback, ConsumerShutdownSignalCallback) - 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, 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, 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>, DeliverCallback, 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, CancelCallback, ConsumerShutdownSignalCallback) - 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, 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, CancelCallback, ConsumerShutdownSignalCallback) - 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, 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, CancelCallback, ConsumerShutdownSignalCallback) - 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.
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, 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
 
basicPublish(String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
basicQos(int) - 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, int, boolean) - 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(Object, Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
Bind the given resource for the given key to the current thread.
bind(Exchange) - Static method in class org.springframework.amqp.core.BindingBuilder
 
bind(Queue) - Static method in class org.springframework.amqp.core.BindingBuilder
 
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_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
 
Binding.DestinationType - Enum in org.springframework.amqp.core
The binding destination.
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
 
bindings() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Array of QueueBindings providing the listener's queue names, together with the exchange and optional binding information.
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, 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.
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>, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, 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(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(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory for the given target ConnectionFactory.
CachingConnectionFactory(String) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory given a host name.
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.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(String, Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Callable binding the given ConnectionFactory and finally unbinding it.
call(Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
Execute a Callable binding to the default 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
 
capture() - Method in annotation type org.springframework.amqp.rabbit.test.RabbitListenerTest
Set to true to advise the listener with a capture advice,
categories() - Method in annotation type org.springframework.amqp.rabbit.junit.LogLevels
Category names representing Log4j or Logback categories to change.
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 - org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
Cache channels - single connection.
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
 
classes() - Method in annotation type org.springframework.amqp.rabbit.junit.LogLevels
Classes representing Log4j categories to change.
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
 
clientLocal - org.springframework.amqp.core.QueueBuilder.LeaderLocator
Deploy on the node we are connected to.
clientLocal - org.springframework.amqp.core.QueueBuilder.MasterLocator
Deprecated.
Deploy on the node we are connected to.
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() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
close() - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
 
close() - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
close(int, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
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(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Perform a commit or message acknowledgement, as appropriate.
commitIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
Commit the Channel if not within a JTA transaction.
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
 
concurrency() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Set the concurrency of the listener container for this listener.
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(CorrelationData, boolean, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
Confirmation callback.
Confirm(boolean, String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
 
confirmSelect() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
Connection - Interface in org.springframework.amqp.rabbit.connection
 
CONNECTION - org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
Cache connections and channels within each 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 - Variable in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
An interface based ConnectionFactory for creating Connections.
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
 
ConsumerCustomizer - Interface in org.springframework.rabbit.stream.listener
Customizer for ConsumerBuilder.
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 MessageListenerContainer> - Interface in org.springframework.amqp.rabbit.config
Called by the container factory after the container is created and configured.
containerFactory() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
The bean name of the RabbitListenerContainerFactory to use to create the message listener container responsible to serve this endpoint.
containerType() - Method in annotation type org.springframework.amqp.rabbit.test.context.SpringRabbitTest
Set the container type to determine which container factory to configure.
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(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(Object) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
Convert to and send a Spring AMQP message.
convertAndSend(Object) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
 
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(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
Convert to and send a Spring AMQP message.
convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
 
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(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(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) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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, Map<String, Object>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
converterWinsContentType() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Set to 'false' to override any content type headers set by the message converter with the value of the 'replyContentType' property.
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(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(Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
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(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
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, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, 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.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, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, 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.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key.
convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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, Map<String, Object>, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
convertSendAndReceive(String, 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.AsyncAmqpTemplate
Convert the object to a message and send it to the provided exchange and routing key after invoking the MessagePostProcessor.
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceive(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceive(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(Object, MessagePostProcessor, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
Basic RPC pattern with conversion.
convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
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(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertSendAndReceiveAsType(String, String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
Basic RPC pattern with conversion.
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(String, String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
convertSendAndReceiveAsType(String, 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 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
 
CORRELATED - org.springframework.amqp.rabbit.connection.CachingConnectionFactory.ConfirmType
Use with CorrelationData to correlate confirmations with sent messsages.
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(boolean) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
 
createChannel(Channel, ExecutorService) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelFactory
Create a PublisherCallbackChannel instance based on the provided delegate and executor.
createChannel(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Create a new RabbitMQ Session for registration with a RabbitResourceHolder.
createClient(String, String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
Create a client instance.
createConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
 
createConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Create a new RabbitMQ Connection for registration with a RabbitResourceHolder.
createConnection() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
createConnection() - Method in class org.springframework.amqp.rabbit.connection.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
 
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.
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
 
createContainerInstance() - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
Create an instance of the listener container.
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() - 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) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
 
createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
 
createListenerContainer(RabbitListenerEndpoint) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
 
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) - 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.
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.
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) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
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
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(Collection<? extends Declarable>) - Constructor for class org.springframework.amqp.core.Declarables
 
Declarables(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 in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
declare() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
 
declare() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
 
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() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Declares a server-named exclusive, autodelete, non-durable queue.
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.
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.
DefaultStreamMessageConverter - Class in org.springframework.rabbit.stream.support.converter
DefaultStreamMessageConverter() - Constructor for class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
Construct an instance using a WrapperMessageBuilder.
DefaultStreamMessageConverter(Codec) - Constructor for class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
Construct an instance using the provided codec.
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.
delayed() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
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) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
deleteQueue(String, boolean, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
Delete a queue.
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(InputStream, Set<String>, ClassLoader) - Static method in class org.springframework.amqp.utils.SerializationUtils
Deserialize the stream.
deserialize(ObjectInputStream) - 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 - org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean.Type
direct - org.springframework.amqp.rabbit.test.context.SpringRabbitTest.ContainerType
 
DIRECT - Static variable in class org.springframework.amqp.core.ExchangeTypes
Direct exchange.
directExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
Return a DirectExchange builder.
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
 
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(MessageListener, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Invoke the specified listener as Spring Rabbit MessageListener.
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.
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(Channel, String, String, Message, boolean, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Send the given message to the specified exchange.
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
 
doSend(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSend(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSend(AmqpAppender.Event, LogEvent, MessageProperties) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
 
doSendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Send a message and wait for a reply.
doSendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
doSendAndReceive(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
 
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
 
dropHead - org.springframework.amqp.core.QueueBuilder.Overflow
Drop the oldest message.
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() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
durable() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
Specifies if this queue should be durable.
durable(boolean) - Method in class org.springframework.amqp.core.ExchangeBuilder
Set the durable flag.
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
 
equals(Object) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
 
errorExchangeName - Variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
 
errorHandler() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Set an RabbitListenerErrorHandler to invoke if the listener method throws an exception.
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(ILoggingEvent) - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
 
Event(LogEvent, Map<?, ?>) - Constructor for class org.springframework.amqp.rabbit.log4j2.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() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
 
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 - org.springframework.amqp.core.Binding.DestinationType
Exchange destination.
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, BuiltinExchangeType) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, BuiltinExchangeType, boolean) - 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
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean) - 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, String, 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
 
exchangeDeclareNoWait(String, String, 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) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
exchangeDelete(String, boolean) - 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.
exclusive() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
Specifies if this queue should be exclusive.
exclusive() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
When true, a single consumer in the container will have exclusive use of the RabbitListener.queues(), preventing other consumers from receiving messages from the queues.
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).
executor() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Set the task executor bean name to use for this listener's container; overrides any executor set on the container factory.
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) - Constructor for exception org.springframework.amqp.rabbit.listener.exception.FatalListenerExecutionException
Constructor for ListenerExecutionFailedException.
FatalListenerExecutionException(String, Throwable) - 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) - 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) - Method in class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
 
fromMessage(Message) - Method in interface org.springframework.rabbit.stream.support.converter.StreamMessageConverter
 
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, 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() - Method in class org.springframework.amqp.utils.MapBuilder
 
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.
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.
getAdapter(boolean, Object, Method, boolean, RabbitListenerErrorHandler, BatchingStrategy) - Method in interface org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint.AdapterProvider
Get an adapter instance.
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
Deprecated.
 
getAmqpTemplate() - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
Deprecated.
 
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
 
getBeanName() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
Return the bean name.
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() - 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
 
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.
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.
getConfirmationCode() - Method in exception org.springframework.rabbit.stream.producer.StreamSendException
Return the confirmation code, if available.
getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
 
getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
 
getConnection() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
 
getConnection(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Connection from the given RabbitResourceHolder.
getConnection(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Fetch an appropriate Connection from the given RabbitResourceHolder.
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
 
getContext() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
Return the stream MessageHandler.Context for the message.
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
 
getCreationTime() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getCreationTime().
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
 
getDefaultReceiveQueue() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Return the configured default receive queue.
getDefaultRequeueRejected() - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
Return the defaultRequeueRejected.
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
 
getGroupId() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getGroupId().
getGroupSequence() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getGroupSequence().
getHandlerAdapter() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
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.
getListenerId() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
The 'id' attribute of the listener.
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
Deprecated.
 
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.
getMessageListener() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
 
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
Deprecated.
 
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
Deprecated.
 
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() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Get the total pending confirms count.
getPendingConfirmsCount() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
getPendingConfirmsCount(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
Get the PendingConfirms count.
getPendingConfirmsCount(PublisherCallbackChannel.Listener) - 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() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
 
getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
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
Deprecated.
 
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, Object, InvocationResult) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
Determine a reply-to Address for the given message.
getReplyToAddress(Message, T) - Method in interface org.springframework.amqp.core.ReplyToAddressCallback
 
getReplyToGroupId() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getReplyToGroupId().
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
Deprecated.
 
getRoutingKeyPattern() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
 
getRoutingLookupKey() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the lookup key if the connection factory is a RoutingConnectionFactory; null otherwise.
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
 
getStreamConverter() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
Get a StreamMessageConverter used to convert a Message to a Message.
getSubject() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getSubject().
getSupportedContentType() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
Get the supported content type; only the subtype is checked when decoding, e.g.
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
 
getTo() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
See Properties.getTo().
getTransactionalResourceHolder() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
 
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.
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(Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
getValue(EvaluationContext, Object, 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.
group() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
If provided, the listener container for this listener will be added to a bean with this value as its name, of type Collection<MessageListenerContainer>.
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(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.
handle(R) - Method in interface org.springframework.amqp.core.ReceiveAndReplyCallback
 
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(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
 
handleError(Message, Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.amqp.rabbit.listener.api.RabbitListenerErrorHandler
Handle the error.
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(DelegatingInvocableHandler) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Construct an instance with the provided delegating handler.
HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Construct an instance with the provided method.
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(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleReturn(Return) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
Handle a returned message.
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
 
hashCode() - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
 
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
 
host() - Method in annotation type org.springframework.amqp.rabbit.test.context.SpringRabbitTest
Set the host when not using RabbitAvailable.

I

id() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
The unique identifier of the container managing for this endpoint.
ignoreDeclarationExceptions() - Method in class org.springframework.amqp.core.ExchangeBuilder
Switch on ignore exceptions such as mismatched properties when declaring.
ignoreDeclarationExceptions() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
ignoreDeclarationExceptions() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
 
ignoreDeclarationExceptions() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
 
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(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
 
ImmediateAcknowledgeAmqpException(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(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
 
ImmediateRequeueAmqpException(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
 
INFERRED - org.springframework.amqp.support.converter.Jackson2JavaTypeMapper.TypePrecedence
 
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
 
INORDER - org.springframework.amqp.rabbit.connection.AbstractConnectionFactory.AddressShuffleMode
Shuffle the addresses after opening a connection, moving the first address to the end.
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.
internal() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
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(MethodInvocation) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
Deprecated.
 
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.
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
 
isAsyncReplies() - Method in interface org.springframework.amqp.core.MessageListener
Return true if this listener is request/reply and the replies are async.
isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
Return true if any handler method has an async reply type.
isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
Return true if any handler method has an async reply type.
isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
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
 
isAutoStartup() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
 
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() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this listener container's Channel handling and not by an external transaction coordinator.
isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.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.
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
 
isDefault() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitHandler
When true, designate that this is the default fallback method if the payload type matches no other RabbitHandler method.
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() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
 
isFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
 
isFatal(Throwable) - Method in interface org.springframework.amqp.rabbit.listener.FatalExceptionStrategy
 
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
 
isProjectionUsed() - Method in class org.springframework.amqp.core.MessageProperties
Get an internal flag used to communicate that conversion used projection; always false at the application level.
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
 
isRedeclareManualDeclarations() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Normally, when a connection is recovered, the admin only recovers auto-delete queues, etc, that are declared as beans in the application context.
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
 
isRunning() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
 
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
Deprecated.
 
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.logback.AmqpAppender
 
isUseSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
 
isVerifyHostname() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
Return true (default) if TLS hostname verification is enabled.
isWritable(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
isWritable(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
 
isWritable(EvaluationContext, 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(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.
Jackson2JsonMessageConverter(String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
Construct with an internal 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(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.
Jackson2XmlMessageConverter(String...) - Constructor for class org.springframework.amqp.support.converter.Jackson2XmlMessageConverter
Construct with an internal 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
 

K

key() - Method in annotation type org.springframework.amqp.rabbit.annotation.QueueBinding
 

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.
level() - Method in annotation type org.springframework.amqp.rabbit.junit.LogLevels
The Log4j level name to switch the categories to during the test.
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, 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, Map<String, String>, String[], String, String, String, boolean, String, String, String, String) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
LocalizedQueueConnectionFactory(ConnectionFactory, Map<String, String>, String[], String, String, String, boolean, Resource) - Constructor for class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
 
log - Variable in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
 
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.
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
 
logger - Variable in class org.springframework.rabbit.stream.listener.StreamListenerContainer
 
logger - Variable in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
 
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

management() - Method in annotation type org.springframework.amqp.rabbit.junit.RabbitAvailable
Requires the management plugin to be available.
MANUAL - org.springframework.amqp.core.AcknowledgeMode
Manual acks - user must ack/nack via a channel aware listener.
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() - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
Return the producer's MessageBuilder to create native stream messages.
messageBuilder() - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
 
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) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
MessageConversionException(String, Throwable) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
messageConverter() - Method in annotation type org.springframework.amqp.rabbit.annotation.RabbitListener
Override the container factory's message converter used for this listener.
messageConverter() - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
Return the message converter.
messageConverter() - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
 
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, 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.
MessageListenerAdapter(Object, MessageConverter) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
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
 
MethodRabbitListenerEndpoint.AdapterProvider - Interface in org.springframework.amqp.rabbit.listener
Provider of listener adapters.
minLeaders - org.springframework.amqp.core.QueueBuilder.LeaderLocator
Deploy on the node with the fewest queue leaders.
minMasters - org.springframework.amqp.core.QueueBuilder.MasterLocator
Deprecated.
Deploy on the node with the fewest masters.
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
Deprecated.
- no longer used.
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
 
name() - Method in annotation type org.springframework.amqp.rabbit.annotation.Argument
Return the argument name.
name() - Method in annotation type org.springframework.amqp.rabbit.annotation.Exchange
 
name() - Method in annotation type org.springframework.amqp.rabbit.annotation.Queue
 
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
 
NON_PERSISTENT - org.springframework.amqp.core.MessageDeliveryMode
Non persistent.
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.
NONE - org.springframework.amqp.core.AcknowledgeMode
No acks - autoAck=true in Channel.basicConsume().
NONE - org.springframework.amqp.rabbit.connection.AbstractConnectionFactory.AddressShuffleMode
Do not shuffle the addresses before or after opening a connection; attempt connections in a fixed order.
NONE - org.springframework.amqp.rabbit.connection.CachingConnectionFactory.ConfirmType
Publisher confirms are disabled (default).
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(Channel, boolean) - Method in interface org.springframework.amqp.rabbit.connection.ShutDownChannelListener
 
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(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) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
onMessage(Message) - Method in interface org.springframework.amqp.rabbit.listener.api.ChannelAwareMessageListener
 
onMessage(Message) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
Deprecated.
 
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
 
onMessage(Message, Channel) - 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.
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
 
onStreamMessage(Message, MessageHandler.Context) - Method in class org.springframework.rabbit.stream.listener.adapter.StreamMessageListenerAdapter
 
onStreamMessage(Message, MessageHandler.Context) - Method in interface org.springframework.rabbit.stream.listener.StreamMessageListener
Process a message.
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
 
org.springframework.rabbit.stream.config - package org.springframework.rabbit.stream.config
Provides classes for stream listener configuration.
org.springframework.rabbit.stream.listener - package org.springframework.rabbit.stream.listener
Provides classes for stream listeners.
org.springframework.rabbit.stream.listener.adapter - package org.springframework.rabbit.stream.listener.adapter
Provides classes for stream listener adapters.
org.springframework.rabbit.stream.producer - package org.springframework.rabbit.stream.producer
Provides classes for stream producers.
org.springframework.rabbit.stream.support - package org.springframework.rabbit.stream.support
Provides support classes.
org.springframework.rabbit.stream.support.converter - package org.springframework.rabbit.stream.support.converter
Provides classes for message conversion.
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
 
password() - Method in annotation type org.springframework.amqp.rabbit.test.context.SpringRabbitTest
Set the password when not using RabbitAvailable.
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
 
PERSISTENT - org.springframework.amqp.core.MessageDeliveryMode
Persistent.
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.
port() - Method in annotation type org.springframework.amqp.rabbit.test.context.SpringRabbitTest
Set the port when not using RabbitAvailable.
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) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor