Index

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 and Interfaces|All Packages|Constant Field Values|Serialized Form

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 Class in org.springframework.amqp.rabbit.connection
The mode used to shuffle the addresses.
AbstractConnectionFactory.DefaultChannelCloseLogger - Class in org.springframework.amqp.rabbit.connection
Default implementation of ConditionalExceptionLogger for logging channel close exceptions.
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.DefaultExclusiveConsumerLogger - Class in org.springframework.amqp.rabbit.listener
Default implementation of ConditionalExceptionLogger for logging exclusive consumer failures.
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
 
AbstractTestContainerTests - Class in org.springframework.amqp.rabbit.junit
 
AbstractTestContainerTests() - Constructor for class org.springframework.amqp.rabbit.junit.AbstractTestContainerTests
 
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() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
Override the container factory AcknowledgeMode property.
AcknowledgeMode - Enum Class 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...) - 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.
addConsumerArg(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
When using receive methods with a non-zero timeout, a Consumer is created to receive the message.
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() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
Reference to a AmqpAdmin.
admins() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
Return a list of admin bean names that should declare this component.
admins() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Queue
Return a list of admin bean names that should declare this component.
admins() - Element in annotation interface 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.support.converter.DefaultClassMapper
afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
 
afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
 
afterPropertiesSet() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
 
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
 
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
 
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
 
AmqpMessageHandlerMethodFactory - Class in org.springframework.amqp.rabbit.listener.adapter
Extension of the DefaultMessageHandlerMethodFactory for Spring AMQP requirements.
AmqpMessageHandlerMethodFactory() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.AmqpMessageHandlerMethodFactory
 
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, 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.
amqpPort() - Static method in class org.springframework.amqp.rabbit.junit.AbstractTestContainerTests
 
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 Interface 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() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
 
arguments() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Queue
 
arguments() - Element in annotation interface 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 using CompletableFutures.
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
 
asyncFailure(Message, Channel, Throwable, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
 
asyncFailure(Message, Channel, Throwable, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
 
AsyncRabbitTemplate - Class in org.springframework.amqp.rabbit
Provides asynchronous send and receive operations returning a CompletableFuture 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.
asyncRpc(Method) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
 
AUTO - Enum constant in enum class 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() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
 
autoDelete() - Element in annotation interface 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() - Element in annotation interface 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
 
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 and Interfaces|All Packages|Constant Field Values|Serialized Form