- 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
-
- AbstractCompressingPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
- 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.
- AbstractDeclarable - Class in org.springframework.amqp.core
-
- AbstractDeclarable() - Constructor for class org.springframework.amqp.core.AbstractDeclarable
-
- AbstractDecompressingPostProcessor - Class in org.springframework.amqp.support.postprocessor
-
- AbstractDecompressingPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
- AbstractDecompressingPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
- 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
-
- 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.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
-
- AbstractRabbitListenerContainerFactory<C extends AbstractMessageListenerContainer> - Class in org.springframework.amqp.rabbit.config
-
- 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
-
- AbstractRoutingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.amqp.utils.JavaUtils
-
- AcknowledgeMode - Enum in org.springframework.amqp.core
-
Acknowledgment modes supported by the listener container.
- ActiveObjectCounter<T> - Class in org.springframework.amqp.rabbit.listener
-
A mechanism to keep track of active objects.
- ActiveObjectCounter() - Constructor for class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- actualInvokeListener(Channel, Message) - 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.listener.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
-
- addAndStartConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- addArgument(String, Object) - Method in class org.springframework.amqp.core.AbstractExchange
-
Add an argument to the arguments.
- addBeforePublishPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add
MessagePostProcessor
that will be invoked immediately before invoking
Channel#basicPublish()
, after all other processing, except creating the
AMQP.BasicProperties
from
MessageProperties
.
- addBlockedListener(BlockedListener) - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Add a BlockedListener
.
- addBlockedListener(BlockedListener) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- addChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addChannel(Channel, Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addChannelListener(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- addConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- addConfirmListener(ConfirmCallback, ConfirmCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- addConnection(Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
- addConstructorArgBooleanValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with the boolean value of that attribute if it is defined in
the given element or else uses the default provided.
- addConstructorArgParentRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with a reference to a bean with parent id equal to the
attribute if it is defined in the given element.
- addConstructorArgRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with a reference to a bean with id equal to the attribute if
it is defined in the given element.
- addConstructorArgValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with the value of that attribute if it is defined in the given
element.
- addDecompressor(String, MessagePostProcessor) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
Add a message post processor to the map of decompressing MessageProcessors.
- addDelegate(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- addDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- addDelegate(String, MessageConverter) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
Add a delegate converter for the content type.
- addDeliveryTag(Channel, long) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addExchange(Exchange) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Add an exchange to the default vhost ('/').
- addExchange(String, Exchange) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Add an exchange to the specified vhost.
- addExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- addExchange(String, Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- addHeader(MessageProperties, String, Class<?>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- additionalHeaders(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
Subclasses can override this method to add more headers to the republished message.
- addListener(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
- addListener(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
Add the listener and return the internal map of pending confirmations for that listener.
- addListener(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add this template as a confirms listener for the provided channel.
- addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Adds a pending confirmation to this channel's map.
- addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- addQueue(Queue) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Add a queue to the default vhost ('/').
- addQueue(String, Queue) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Add a queue to the specified vhost.
- addQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- addQueue(String, Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueueOrTagToMethodName(String, String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Add the mapping of a queue name or consumer tag to a method name.
- addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addRecoveryListenerIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
-
Add a listener if necessary so we can immediately close an autorecovered
channel if necessary since the actual consumer will no longer exist.
- Address - Class in org.springframework.amqp.core
-
Represents an address for publication of an AMQP message.
- Address(String) - Constructor for class org.springframework.amqp.core.Address
-
Create an Address instance from a structured String with the form
(exchange)/(routingKey)
- Address(String, String) - Constructor for class org.springframework.amqp.core.Address
-
Create an Address given the exchange name and routing key.
- ADDRESS - Static variable in class org.springframework.amqp.support.SendRetryContextAccessor
-
Key for the Address we tried to send to.
- addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- addReturnListener(ReturnCallback) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
Added to the 5.0.x client.
- addShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- addTargetConnectionFactory(Object, ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- addToBatch(String, String, Message) - Method in interface org.springframework.amqp.rabbit.core.support.BatchingStrategy
-
Add a message to the batch and optionally release the batch.
- addToBatch(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
-
- 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.
- addWhiteListPatterns(String...) - Static method in class org.springframework.amqp.core.Message
-
Add patterns to the white list of permissable package/class name patterns for
deserialization in
Message.toString()
.
- addWhiteListPatterns(String...) - Method in class org.springframework.amqp.support.converter.WhiteListDeserializingMessageConverter
-
Add package/class patterns to the white list.
- adjustConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Adjust consumers depending on delta.
- admins(Object...) - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Admins, or admin bean names that should declare this exchange.
- afterAll(ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
-
- 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 class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
Make sure the ConnectionFactory has been set.
- afterPropertiesSet() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
- afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
- afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
-
- afterSingletonsInstantiated() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- AMQ_RABBITMQ_REPLY_TO - Static variable in class org.springframework.amqp.core.Address
-
Use this value in RabbitTemplate#setReplyAddress(String)
to explicitly
indicate that direct reply-to is to be used.
- AmqpAdmin - Interface in org.springframework.amqp.core
-
Specifies a basic set of portable AMQP administrative operations for AMQP > 0.9.
- AmqpAppender - Class in org.springframework.amqp.rabbit.log4j2
-
A Log4j 2 appender that publishes logging events to an AMQP Exchange.
- AmqpAppender(String, Filter, Layout<? extends Serializable>, boolean, AmqpAppender.AmqpManager, BlockingQueue<AmqpAppender.Event>) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
- AmqpAppender - Class in org.springframework.amqp.rabbit.logback
-
A Logback appender that publishes logging events to an AMQP Exchange.
- AmqpAppender() - Constructor for class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- AmqpAppender.AmqpManager - Class in org.springframework.amqp.rabbit.log4j2
-
Manager class for the appender.
- AmqpAppender.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
-
- AmqpClientInterceptor() - Constructor for class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- AmqpConnectException - Exception in org.springframework.amqp
-
RuntimeException wrapper for an
ConnectException
which can be commonly
thrown from AMQP operations if the remote process dies or there is a network issue.
- AmqpConnectException(Exception) - Constructor for exception org.springframework.amqp.AmqpConnectException
-
Construct an instance with the supplied message and cause.
- AmqpConnectException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpConnectException
-
Construct an instance with the supplied message and cause.
- AmqpEvent - Class in org.springframework.amqp.event
-
Base class for events.
- AmqpEvent(Object) - Constructor for class org.springframework.amqp.event.AmqpEvent
-
- AmqpException - Exception in org.springframework.amqp
-
Base RuntimeException for errors that occur when executing AMQP operations.
- AmqpException(String) - Constructor for exception org.springframework.amqp.AmqpException
-
- AmqpException(Throwable) - Constructor for exception org.springframework.amqp.AmqpException
-
- AmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpException
-
- AmqpHeaderMapper - Interface in org.springframework.amqp.support
-
Strategy interface for mapping messaging Message headers to an outbound
MessageProperties
(e.g.
- AmqpHeaders - Class in org.springframework.amqp.support
-
Pre-defined names and prefixes to be used for setting and/or retrieving AMQP
MessageProperties from/to
Message
Headers.
- AmqpHeaders() - Constructor for class org.springframework.amqp.support.AmqpHeaders
-
- AmqpIllegalStateException - Exception in org.springframework.amqp
-
Equivalent of an IllegalStateException but within the AmqpException hierarchy.
- AmqpIllegalStateException(String) - Constructor for exception org.springframework.amqp.AmqpIllegalStateException
-
- AmqpIllegalStateException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpIllegalStateException
-
- AmqpInvokerServiceExporter - Class in org.springframework.amqp.remoting.service
-
This message listener exposes a plain java service via AMQP.
- AmqpInvokerServiceExporter() - Constructor for class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
- AmqpIOException - Exception in org.springframework.amqp
-
RuntimeException wrapper for an
IOException
which
can be commonly thrown from AMQP operations.
- AmqpIOException(IOException) - Constructor for exception org.springframework.amqp.AmqpIOException
-
Construct an instance with the provided cause.
- AmqpIOException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpIOException
-
Construct an instance with the provided message and cause.
- AmqpManagementOperations - Interface in org.springframework.amqp.core
-
- AmqpManager(LoggerContext, String) - Constructor for class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
-
- AmqpMessageHeaderAccessor - Class in org.springframework.amqp.support
-
- 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 in an RPC scenario 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
-
- AmqpProxyFactoryBean - Class in org.springframework.amqp.remoting.client
-
- AmqpProxyFactoryBean() - Constructor for class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- AmqpRejectAndDontRequeueException - Exception in org.springframework.amqp
-
Exception for listener implementations used to indicate the
basic.reject will be sent with requeue=false in order to enable
features such as DLQ.
- AmqpRejectAndDontRequeueException(String) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
Construct an instance with the supplied argument.
- AmqpRejectAndDontRequeueException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
Construct an instance with the supplied argument.
- AmqpRejectAndDontRequeueException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
Construct an instance with the supplied arguments.
- AmqpRejectAndDontRequeueException(String, boolean, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
Construct an instance with the supplied arguments.
- AmqpRemoteException - Exception in org.springframework.amqp
-
An exception that wraps an exception thrown by the server in a
request/reply scenario.
- AmqpRemoteException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRemoteException
-
- AmqpReplyTimeoutException - Exception in org.springframework.amqp.core
-
Async reply timeout.
- AmqpReplyTimeoutException(String, Message) - Constructor for exception org.springframework.amqp.core.AmqpReplyTimeoutException
-
- AmqpResourceNotAvailableException - Exception in org.springframework.amqp
-
- AmqpResourceNotAvailableException(String) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
-
- AmqpResourceNotAvailableException(Throwable) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
-
- AmqpResourceNotAvailableException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpResourceNotAvailableException
-
- AmqpTemplate - Interface in org.springframework.amqp.core
-
Specifies a basic set of AMQP operations.
- AmqpTimeoutException - Exception in org.springframework.amqp
-
Exception thrown when some time-bound operation fails to execute in the
desired time.
- AmqpTimeoutException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
-
- AmqpTimeoutException(String) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
-
- AmqpTimeoutException(Throwable) - Constructor for exception org.springframework.amqp.AmqpTimeoutException
-
- AmqpUnsupportedEncodingException - Exception in org.springframework.amqp
-
RuntimeException for unsupported encoding in an AMQP operation.
- AmqpUnsupportedEncodingException(Throwable) - Constructor for exception org.springframework.amqp.AmqpUnsupportedEncodingException
-
- and(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
-
- andProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilder
-
Makes this builder's properties builder use a reference to properties.
- AnonymousQueue - Class in org.springframework.amqp.core
-
Represents an anonymous, non-durable, exclusive, auto-delete queue.
- AnonymousQueue() - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
Construct a queue with a Base64-based name.
- AnonymousQueue(Map<String, Object>) - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
Construct a queue with a Base64-based name with the supplied arguments.
- AnonymousQueue(AnonymousQueue.NamingStrategy) - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
- AnonymousQueue(AnonymousQueue.NamingStrategy, Map<String, Object>) - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
- 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.
- AnonymousQueue.Base64UrlNamingStrategy - Class in org.springframework.amqp.core
-
- AnonymousQueue.NamingStrategy - Interface in org.springframework.amqp.core
-
- AnonymousQueue.UUIDNamingStrategy - Class in org.springframework.amqp.core
-
- answer(InvocationOnMock) - Method in class org.springframework.amqp.rabbit.test.mockito.LambdaAnswer
-
- answer(InvocationOnMock) - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
-
- APP_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- append(LogEvent) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
- append(ILoggingEvent) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
Key name for the application id (if there is one set via the appender config) in the message properties.
- APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Key name for the application id (if there is one set via the appender config) in the message properties.
- apply(Statement, Description) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- apply(Statement, Description) - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
-
- apply(InvocationOnMock, T) - Method in interface org.springframework.amqp.rabbit.test.mockito.LambdaAnswer.ValueToReturn
-
- applyCommonSettings(AbstractRetryOperationsInterceptorFactoryBean) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
- Argument - Annotation Type in org.springframework.amqp.rabbit.annotation
-
Represents an argument used when declaring queues etc within a
QueueBinding
.
- ArgumentBuilder - Class in org.springframework.amqp.rabbit.support
-
A builder for argument maps.
- ArgumentBuilder() - Constructor for class org.springframework.amqp.rabbit.support.ArgumentBuilder
-
- AsyncAmqpTemplate - Interface in org.springframework.amqp.core
-
Classes implementing this interface can perform asynchronous send and
receive operations.
- asyncCompletableRpc(Method) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
Added to the 5.0.x client.
- AsyncConsumerRestartedEvent - Class in org.springframework.amqp.rabbit.listener
-
An event that is published whenever a consumer is restarted.
- AsyncConsumerRestartedEvent(Object, Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
-
- AsyncConsumerStartedEvent - Class in org.springframework.amqp.rabbit.listener
-
An event that is published whenever a new consumer is started.
- AsyncConsumerStartedEvent(Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
-
- AsyncConsumerStoppedEvent - Class in org.springframework.amqp.rabbit.listener
-
An event that is published whenever a consumer is stopped (and not restarted).
- AsyncConsumerStoppedEvent(Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
-
- AsyncRabbitTemplate - Class in org.springframework.amqp.rabbit
-
Provides asynchronous send and receive operations returning a
ListenableFuture
allowing the caller to obtain the reply later, using
get()
or a callback.
- AsyncRabbitTemplate(ConnectionFactory, String, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate(ConnectionFactory, String, String, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate(RabbitTemplate, AbstractMessageListenerContainer) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate(RabbitTemplate, AbstractMessageListenerContainer, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate(ConnectionFactory, String, String) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate(RabbitTemplate) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Construct an instance using the provided arguments.
- AsyncRabbitTemplate.RabbitConverterFuture<C> - Class in org.springframework.amqp.rabbit
-
- AsyncRabbitTemplate.RabbitFuture<T> - Class in org.springframework.amqp.rabbit
-
- AsyncRabbitTemplate.RabbitMessageFuture - Class in org.springframework.amqp.rabbit
-
- asyncRpc(Method) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- autoDelete() - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Set the auto delete flag.
- autoDelete() - Method in class org.springframework.amqp.core.QueueBuilder
-
The final queue will auto delete.
- AutoRecoverConnectionNotCurrentlyOpenException - Exception in org.springframework.amqp.rabbit.connection
-
An exception thrown if the connection is an auto recover connection that is not
currently open and is in the process of being recovered.
- await(long, TimeUnit) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- await(int) - Method in class org.springframework.amqp.rabbit.test.mockito.LatchCountDownAndCallRealMethodAnswer
-
Wait for the latch to count down.
- CachingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
-
- CachingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory initializing the hostname to be the value returned from
InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
- CachingConnectionFactory(String) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a host name.
- CachingConnectionFactory(int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a port on the hostname returned from
InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
- CachingConnectionFactory(String, int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a host name
and port.
- CachingConnectionFactory(URI) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a
URI
.
- CachingConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory for the given target ConnectionFactory.
- CachingConnectionFactory.CacheMode - Enum in org.springframework.amqp.rabbit.connection
-
The cache mode.
- 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
-
- 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
-
- causeChainHasImmediateAcknowledgeAmqpException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.
- 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.
- 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
-
- checkWhiteList(Class<?>) - Method in class org.springframework.amqp.support.converter.WhiteListDeserializingMessageConverter
-
- checkWhiteList(Class<?>, Set<String>) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
Verify that the class is in the white list.
- 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
-
- clearReturnListeners() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- close() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Close this connection and all its channels
with the AMQP.REPLY_SUCCESS
close code
and message 'OK'.
- close(int, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- close() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- closeAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- closeAndClear(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- closeChannel(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Close the given RabbitMQ Channel and ignore any thrown exception.
- closeChannels(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- closeConnection(Connection) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Close the given RabbitMQ Connection and ignore any thrown exception.
- closeMessageConsumer(Channel, Collection<String>, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- ClosingRecoveryListener - Class in org.springframework.amqp.rabbit.connection
-
A RecoveryListener
that closes the recovered channel, to avoid
orphaned consumers.
- CLUSTER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- commitAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- commitIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Commit the Channel if not within a JTA transaction.
- commitIfNecessary(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Perform a commit or message acknowledgement, as appropriate.
- CompositeChannelListener - Class in org.springframework.amqp.rabbit.connection
-
- CompositeChannelListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- CompositeConnectionListener - Class in org.springframework.amqp.rabbit.connection
-
- CompositeConnectionListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- ConditionalExceptionLogger - Interface in org.springframework.amqp.support
-
For components that support customization of the logging of certain events, users can
provide an implementation of this interface to modify the existing logging behavior.
- ConditionalRejectingErrorHandler - Class in org.springframework.amqp.rabbit.listener
-
- ConditionalRejectingErrorHandler() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
- ConditionalRejectingErrorHandler(FatalExceptionStrategy) - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
- ConditionalRejectingErrorHandler.DefaultExceptionStrategy - Class in org.springframework.amqp.rabbit.listener
-
- 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
-
- 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
-
- configureTrustManagers() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- Confirm(boolean, String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
-
- confirm(CorrelationData, boolean, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
-
Confirmation callback.
- confirmSelect() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- Connection - Interface in org.springframework.amqp.rabbit.connection
-
- CONNECTION_PROTOCOL_CLASS_ID_10 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
AMQP Connection protocol class id.
- ConnectionBlockedEvent - Class in org.springframework.amqp.rabbit.connection
-
The
AmqpEvent
emitted by the
CachingConnectionFactory
when its connections are blocked.
- ConnectionBlockedEvent(Connection, String) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
-
- ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
-
An interface based ConnectionFactory for creating Connections
.
- connectionFactory - Variable in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- ConnectionFactoryConfigurationUtils - Class in org.springframework.amqp.rabbit.connection
-
Utility methods for configuring connection factories.
- ConnectionFactoryUtils - Class in org.springframework.amqp.rabbit.connection
-
Helper class for managing a Spring based Rabbit
ConnectionFactory
,
in particular for obtaining transactional Rabbit resources for a given ConnectionFactory.
- ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.amqp.rabbit.connection
-
Callback interface for resource creation.
- ConnectionListener - Interface in org.springframework.amqp.rabbit.connection
-
A listener for connection creation and closing.
- ConnectionNameStrategy - Interface in org.springframework.amqp.rabbit.connection
-
A strategy to build an application-specific connection name,
which can be displayed in the management UI if RabbitMQ server supports it.
- ConnectionProxy - Interface in org.springframework.amqp.rabbit.connection
-
Subinterface of
Connection
to be implemented by
Connection proxies.
- ConnectionUnblockedEvent - Class in org.springframework.amqp.rabbit.connection
-
The
AmqpEvent
emitted by the
CachingConnectionFactory
when its connections are unblocked.
- ConnectionUnblockedEvent(Connection) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
-
- CONSUME_METHOD_ID_20 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
AMQP consume method.
- ConsumeOkEvent - Class in org.springframework.amqp.rabbit.listener
-
An
AmqpEvent
emitted by the listener container
when consumer is subscribed to the queue.
- ConsumeOkEvent(Object, String, String) - Constructor for class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
-
Instantiate a
ConsumeOkEvent
based on the provided
consumer, queue and consumer tag.
- ConsumeOkNotReceivedException - Exception in org.springframework.amqp.rabbit.core
-
Thrown when a blocking receive operation is performed but the consumeOk
was not received before the receive timeout.
- ConsumeOkNotReceivedException(String) - Constructor for exception org.springframework.amqp.rabbit.core.ConsumeOkNotReceivedException
-
- CONSUMER_QUEUE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
The queue from which the listener container consumer received the message.
- CONSUMER_TAG - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
The tag of the listener container consumer that received the message.
- ConsumerCancelledException - Exception in org.springframework.amqp.rabbit.support
-
Thrown when the broker cancels the consumer and the message
queue is drained.
- ConsumerCancelledException() - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
-
- ConsumerCancelledException(Throwable) - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
-
- ConsumerChannelRegistry - Class in org.springframework.amqp.rabbit.connection
-
Consumers register their primary channels with this class.
- consumerCount(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Called whenever a consumer is removed.
- consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- consumers - Variable in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- consumersMonitor - Variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- ConsumerTagStrategy - Interface in org.springframework.amqp.support
-
A strategy interface to determine the consumer tag to be used when issuing a
basicConsume
operation.
- containerAckMode(AcknowledgeMode) - Method in interface org.springframework.amqp.core.MessageListener
-
Called by the container to inform the listener of its acknowledgement
mode.
- containerAckMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
- ContainerUtils - Class in org.springframework.amqp.rabbit.listener
-
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
-
- ContentTypeDelegatingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
- ContentTypeDelegatingMessageConverter(MessageConverter) - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
Constructs an instance using a the supplied default converter.
- convertAmqpException(RuntimeException) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAmqpMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAndSend(Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a default routing key.
- convertAndSend(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a specific routing key.
- convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a specific exchange
with a specific routing key.
- convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a default routing key.
- convertAndSend(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Convert a Java object to an Amqp
Message
and send it to a specific exchange
with a specific routing key.
- convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given Object to serialized form, possibly using a
MessageConverter
,
wrap it as a message and send it to a specific exchange with a
specific routing key.
- convertAndSend(String, String, Object, Map<String, Object>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given Object to serialized form, possibly using a
MessageConverter
,
wrap it as a message with the given headers and send it to a
specific exchange with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given Object to serialized form, possibly using a
MessageConverter
,
wrap it as a message, apply the given post processor, and send
the resulting message to a specific exchange with a specific
routing key.
- convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given Object to serialized form, possibly using a
MessageConverter
,
wrap it as a message with the given headers, apply the given post processor,
and send the resulting message to a specific exchange with a specific
routing key.
- convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAndSend(String, String, Object, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertAndSend(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a specific routing key.
- convertAndSend(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a specific exchange
with a specific routing key.
- convertAndSend(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a default routing key.
- convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a specific exchange
with a specific routing key.
- convertAndSend(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertMessageIfNecessary(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertRabbitAccessException(Exception) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- convertRabbitAccessException(Throwable) - Static method in class org.springframework.amqp.rabbit.support.RabbitExceptionTranslator
-
- convertSendAndReceive(Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceive(Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
default routing key.
- convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
provided routing key.
- convertSendAndReceive(String, String, Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the provided exchange and
routing key.
- convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
default routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
provided routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the provided exchange and
routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceive(String, String, Object, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given request Object to serialized form, possibly using a
MessageConverter
, send
it as a
Message
to a specific exchange with a specific routing key,
receive the reply and convert its body of the specified target class.
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given request Object to serialized form, possibly using a
MessageConverter
, send
it as a
Message
with the given headers, to a specific exchange
with a specific routing key, receive the reply and convert its body of
the specified target class.
- convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given request Object to serialized form, possibly using a
MessageConverter
,
apply the given post processor and send the resulting
Message
to
a specific exchange with a specific routing key, receive the reply and
convert its body of the given target class.
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Convert the given request Object to serialized form, possibly using a
MessageConverter
,
wrap it as a message with the given headers, apply the given post processor
and send the resulting
Message
to a specific exchange with a
specific routing key,, receive the reply and convert its body of the
given target class.
- convertSendAndReceive(String, String, Object, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- convertSendAndReceive(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
default routing key.
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
provided routing key.
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the provided exchange and
routing key.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
default routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the default exchange with the
provided routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Convert the object to a message and send it to the provided exchange and
routing key after invoking the
MessagePostProcessor
.
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceiveRaw(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Convert and send a message and return the raw reply message, or null.
- copyHeaders(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- copyHeadersIfAbsent(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessagePropertiesBuilder
-
- Correlation - Interface in org.springframework.amqp.core
-
A marker interface for data used to correlate information about sent messages.
- CORRELATION_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- correlationConvertAndSend(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Convert a Java object to an Amqp
Message
and send it to a default exchange
with a default routing key.
- correlationConvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- CorrelationData - Class in org.springframework.amqp.rabbit.connection
-
Base class for correlating publisher confirms to sent messages.
- CorrelationData() - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
-
Construct an instance with a null Id.
- CorrelationData(String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
-
Construct an instance with the supplied id.
- CorrelationData.Confirm - Class in org.springframework.amqp.rabbit.connection
-
Represents a publisher confirmation.
- CorrelationDataPostProcessor - Interface in org.springframework.amqp.rabbit.core
-
A callback invoked immediately before publishing a message to update, replace, or
create correlation data for publisher confirms.
- counter - Variable in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- createAppender(Configuration, String, Layout<? extends Serializable>, Filter, boolean, URI, String, String, String, String, String, String, boolean, boolean, String, String, String, String, String, String, String, String, String, int, int, String, String, boolean, String, String, String, boolean, boolean, boolean, String, String, String, String, boolean, String, int, BlockingQueueFactory<AmqpAppender.Event>, boolean) - Static method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
- createBareConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- createBlockingQueueConsumer() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- createChannel(boolean) - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Create a new channel, using an internally allocated channel number.
- createChannel(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Create a new RabbitMQ Session for registration with a RabbitResourceHolder.
- createChannel(Channel, ExecutorService) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelFactory
-
- createChannel(boolean) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- createClient(String, String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
Create a client instance.
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- createConnection(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Create a connection with this connection factory and/or its publisher factory.
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Create a new RabbitMQ Connection for registration with a RabbitResourceHolder.
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Create a RabbitMQ Connection via this template's ConnectionFactory and its host and port values.
- createConnectionFactory(String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
Create a dedicated connection factory for the address.
- createConsumerTag(String) - Method in interface org.springframework.amqp.support.ConsumerTagStrategy
-
Create the consumer tag, optionally based on the queue name that the consumer
will listen to.
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Create an empty container instance.
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- createElementDescription(Element) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Provides a user friendly description of an element based on its node name and, if available, its "id" attribute
value.
- createEventQueue() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Subclasses can override this method to inject a custom queue implementation.
- createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
- createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
- createInstance() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- createInstance() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- createInstance() - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
-
- createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- createListenerContainer(RabbitListenerEndpoint) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
-
- createListenerContainer() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
-
- createListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
-
Crate a message from the payload object and message properties provided.
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
-
Crate a message from the payload object and message properties provided.
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Marshals the given object to a
Message
.
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
Creates an AMQP Message from the provided Object.
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
Creates an AMQP Message from the provided Object.
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
-
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Create a
MessageListener
that is able to serve this endpoint for the
specified container.
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
- createMessageListenerInstance() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
- 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
-
- 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
-
- generateId() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Generate the connection id for the connection used by the rule's
connection factory.
- generateName() - Method in class org.springframework.amqp.core.AnonymousQueue.Base64UrlNamingStrategy
-
Deprecated.
- generateName() - Method in class org.springframework.amqp.core.AnonymousQueue.UUIDNamingStrategy
-
Deprecated.
- generateName() - Method in class org.springframework.amqp.core.Base64UrlNamingStrategy
-
- generateName() - Method in interface org.springframework.amqp.core.NamingStrategy
-
- generateName() - Method in class org.springframework.amqp.core.UUIDNamingStrategy
-
- GenericArgumentsConfigurer(BindingBuilder.GenericExchangeRoutingKeyConfigurer, String) - Constructor for class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
-
- get(Object) - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
-
Retrieve a resource for the given key that is bound to the current thread.
- get() - Method in class org.springframework.amqp.utils.MapBuilder
-
- getAcknowledgeMode() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getActiveConsumerCount() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- getActualName() - Method in class org.springframework.amqp.core.Queue
-
Return the name provided to the constructor or the broker-generated name
if that name is an empty String.
- getAddress() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- getAddress(RetryContext) - Static method in class org.springframework.amqp.support.SendRetryContextAccessor
-
Retrieve the
Address
from the context.
- getAddresses() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getAdminPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Return the admin password.
- getAdminUri() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Return the admin uri.
- getAdminUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
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
-
- getAmqpAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getAmqpMessageConverter() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- getAmqpTemplate() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- getAmqpTemplate() - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
- getAppId() - Method in class org.springframework.amqp.core.MessageProperties
-
- getAppId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getApplicationContext() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getApplicationContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getApplicationEventPublisher() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getApplicationEventPublisher() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getApplicationId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getArguments() - Method in class org.springframework.amqp.core.AbstractBuilder
-
- getArguments() - Method in class org.springframework.amqp.core.AbstractExchange
-
- getArguments() - Method in class org.springframework.amqp.core.Binding
-
- 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.core.Queue
-
- 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
-
- getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
-
- getBean() - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
-
- getBean() - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
- getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.DirectExchangeParser
-
- getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.FanoutExchangeParser
-
- getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.HeadersExchangeParser
-
- getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.QueueParser
-
- getBeanClass(Element) - Method in class org.springframework.amqp.rabbit.config.TopicExchangeParser
-
- getBeanExpressionContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getBeanFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getBeanName() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- getBeanName() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Return a bean name of the component or null if not a bean.
- getBeanName() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- getBeanName() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getBeanResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getBindings() - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all bindings.
- getBindings(String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all bindings in the provided vhost.
- getBindings() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getBindings(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getBindingsFailedException() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
Return any exception thrown when attempting to bind the queue to the event exchange.
- getBindingsForExchange(String, String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all bindings from the provided exchange in the provided vhost.
- getBindingsForExchange(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getBody() - Method in class org.springframework.amqp.core.Message
-
- getBody() - Method in class org.springframework.amqp.rabbit.support.Delivery
-
Retrieve the message body.
- getBrokerRunning() - Static method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
-
- getCacheMode() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getCacheProperties() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getCause() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
- getChannel(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Fetch an appropriate Channel from the given RabbitResourceHolder.
- getChannel(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Fetch an appropriate Channel from the given RabbitResourceHolder.
- getChannel() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getChannel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- getChannel() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer.ChannelHolder
-
- getChannelCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getChannelHolder() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
Get the channel holder associated with a direct reply-to consumer; contains a
consumer epoch to prevent inappropriate releases.
- getChannelListener() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
A composite channel listener to be used by subclasses when creating and closing channels.
- getChannelNumber() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getChannelsExecutor() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Determine the executor service used for target channels.
- getCharset() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
The name of the header that contains the type id.
- getClassLoader() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- getClassLoader() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- getClassMapper() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- getClient() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- 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.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
-
- getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
-
- getConnection(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Fetch an appropriate Connection from the given RabbitResourceHolder.
- getConnection() - Method in class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
-
- getConnection() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getConnection(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Fetch an appropriate Connection from the given RabbitResourceHolder.
- getConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getConnection(Class<? extends Connection>) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getConnectionCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
- getConnectionFactory() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Return the connection factory for this operations.
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Get the connection factory used by this rule.
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- getConnectionListener() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
A composite connection listener to be used by subclasses when creating and closing connections.
- getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStartedEvent
-
- getConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerStoppedEvent
-
- 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.
- getConsumerEpoch() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer.ChannelHolder
-
- getConsumerQueue() - Method in class org.springframework.amqp.core.MessageProperties
-
- getConsumerQueue() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getConsumerTag() - Method in class org.springframework.amqp.core.MessageProperties
-
- getConsumerTag() - Method in class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
-
Obtain the consumer tag assigned to the consumer.
- getConsumerTag() - Method in class org.springframework.amqp.rabbit.support.Delivery
-
Retrieve the consumer tag.
- getConsumerTag() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getConsumerTags() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- getConsumerTagStrategy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Return the consumer tag strategy to use.
- getContentClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- getContentEncoding() - Method in class org.springframework.amqp.core.MessageProperties
-
- getContentEncoding() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getContentEncoding() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getContentLength() - Method in class org.springframework.amqp.core.MessageProperties
-
- getContentLength() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getContentType() - Method in class org.springframework.amqp.core.MessageProperties
-
- getContentType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getContentType() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getContextStopped() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getConverterForContentType(String) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
- getCorrelationData() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
The correlation data supplied by the client when sending the message
corresponding to this confirmation.
- getCorrelationId() - Method in class org.springframework.amqp.core.MessageProperties
-
Get the correlation id.
- getCorrelationId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getCount() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- getDeclarable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
-
- getDeclarables() - Method in class org.springframework.amqp.core.Declarables
-
- getDeclaringAdmins() - Method in class org.springframework.amqp.core.AbstractDeclarable
-
- getDeclaringAdmins() - Method in interface org.springframework.amqp.core.Declarable
-
The collection of AmqpAdmin
s 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.UnzipPostProcessor
-
- getDefaultCharset() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- getDefaultConsumer() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getDefaultHostName() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getDefaultListenerMethod() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- getDelay() - Method in class org.springframework.amqp.core.MessageProperties
-
The x-delay header (outbound).
- getDelegate() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Return the underlying RabbitMQ connection.
- getDelegate() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Use this to invoke methods on the underlying rabbit client Channel
that
are not supported by this implementation.
- getDelegate() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getDelegate() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- getDelegate() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- getDelegate(String) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
-
Get the actual listener object (not the spy).
- getDelegates() - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
- getDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
-
- getDeliveryMode() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getDeliveryMode() - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- getDeliveryMode() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getDeliveryTag() - Method in class org.springframework.amqp.core.MessageProperties
-
- getDeliveryTag() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getDestination() - Method in class org.springframework.amqp.core.Binding
-
- getDestinationType() - Method in class org.springframework.amqp.core.Binding
-
- getEncoder() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getEncoding() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The encoding used when converting between byte arrays and Strings in message properties.
- getEncoding() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
The encoding to use when inter-converting between byte arrays and Strings in
message properties.
- getEncoding() - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Get the encoding.
- getEncoding() - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
Get the encoding.
- getEncoding() - Method in class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
-
- getEncoding() - Method in class org.springframework.amqp.support.postprocessor.GZipPostProcessor
-
- 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
-
- getEventType() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
-
- getExchange(String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get a specific queue from the default vhost ('/').
- getExchange(String, String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get a specific exchange from the provided vhost.
- getExchange() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
-
- getExchange() - Method in class org.springframework.amqp.core.Binding
-
- getExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getExchange(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getExchange() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- getExchange() - Method in class org.springframework.amqp.rabbit.core.support.MessageBatch
-
- getExchangeName() - Method in class org.springframework.amqp.core.Address
-
- getExchangeName() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getExchanges() - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all exchanges.
- getExchanges(String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all exchanges in the provided vhost.
- getExchanges() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getExchanges(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- 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.listener.exception.ListenerExecutionFailedException
-
- getFuture() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Return a future to check the success/failure of the publish operation.
- getGroup() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getGroup() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
- getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
-
- 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.
- getId() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
- 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
.
- 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
-
- 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
-
- getListenerContainer(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- getListenerContainerIds() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- getListenerContainers() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- getListenerId() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
The 'id' attribute of the listener.
- getListenerId() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerIdleEvent
-
The id of the listener (if @RabbitListener
) or the container bean name.
- getListenerMethodName(Message, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Determine the name of the listener method that will handle the given message.
- getLocalAddress() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- getLocalPort() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
- getLocalPort() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- getMaxFrame(ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Return the negotiated frame_max.
- getMaxSenderRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getMessage() - Method in class org.springframework.amqp.rabbit.core.support.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.AbstractMessageListenerContainer
-
Deprecated.
- 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.MessageListenerContainer
-
- getMessageConverter() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
Used by the container factory to check if this endpoint supports the
preferred way for a container factory to pass a message converter
to the endpoint's adapter.
- getMessageConverter() - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
- getMessageCount() - Method in class org.springframework.amqp.core.MessageProperties
-
Return the server's most recent estimate of the number of messages remaining on the queue.
- getMessageCount() - Method in class org.springframework.amqp.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
-
- getMessageProperties() - Method in class org.springframework.amqp.core.Message
-
- getMessageProperties() - Method in class org.springframework.amqp.rabbit.core.BrokerEvent
-
- 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.MethodRabbitListenerEndpoint
-
- getMethodAsString(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
-
- getMethodFor(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
-
Return the method that will be invoked for this payload.
- 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.
- getNewConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
-
- getNextInvocationDataFor(String, long, TimeUnit) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
-
- getNextPublishSeqNo() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- getObject() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- getOldConsumer() - Method in class org.springframework.amqp.rabbit.listener.AsyncConsumerRestartedEvent
-
- getOrCreateArguments() - Method in class org.springframework.amqp.core.AbstractBuilder
-
Return the arguments map, after creating one if necessary.
- getOrder() - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- getOrder() - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
- getOrder() - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
- getOrder() - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
- getPassword() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Return the password.
- getPassword() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getPendingConfirmsCount(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
- getPendingConfirmsCount() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Get the total pending confirms count.
- getPendingConfirmsCount(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getPendingConfirmsCount() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- getPhase() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- getPhase() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- getPhase() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- getPhase() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getPhase() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- getPort() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getPort() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- getPort() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- getPort() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
- getPort() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- getPort() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Return the port.
- getPort() - 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
DirectFieldAccessor
s 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(String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get a specific queue from the default vhost ('/').
- getQueue(String, String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get a specific queue from the provided vhost.
- getQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getQueue(String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- 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.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.
- 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
-
- getQueues() - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all queues.
- getQueues(String) - Method in interface org.springframework.amqp.core.AmqpManagementOperations
-
Deprecated.
Get all queues in the provided vhost.
- getQueues() - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getQueues(String) - Method in class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
- getQueues() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getRabbitAdmin() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.core.RabbitAdmin
-
- getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- getReason() - Method in class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
-
- getReason() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
-
- getReason() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
-
- getReason() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerTerminatedEvent
-
- getReceivedDelay() - Method in class org.springframework.amqp.core.MessageProperties
-
When a delayed message exchange is used the x-delay header on a
received message contains the delay.
- getReceivedDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReceivedDeliveryMode() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getReceivedExchange() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
- getReceivedExchange() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getReceivedRoutingKey() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReceivedRoutingKey() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getReceivedUserId() - Method in class org.springframework.amqp.core.MessageProperties
-
Return the user id from an incoming message.
- getReceivedUserId() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getRecoveryBackOff() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
-
- getRedelivered() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getRemoteInvocationFactory() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- getReplyCode() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
-
- getReplyText() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
-
- getReplyTo() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReplyTo() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getReplyToAddress() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReplyToAddress(Message, T) - Method in interface org.springframework.amqp.core.ReplyToAddressCallback
-
- getReplyToAddress(Message, Object, InvocationResult) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Determine a reply-to Address for the given message.
- getRequest() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
-
- getRequestMessage() - Method in exception org.springframework.amqp.core.AmqpReplyTimeoutException
-
- getResolver() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- getResourceFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- 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
-
- getReturnedMessage() - Method in exception org.springframework.amqp.core.AmqpMessageReturnedException
-
- getReturnedMessage() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Return a returned message, if any; requires a unique
id
.
- getReturnType() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
-
- getReturnType(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.
- getReturnType() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
-
- getReturnValue() - Method in class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
-
- getRoutingConnectionFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.rabbit.core.RabbitTemplate
-
- getRoutingKey() - Method in class org.springframework.amqp.rabbit.core.support.MessageBatch
-
- getRoutingKey() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- getRoutingKeyPattern() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getRoutingLookupKey() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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
-
- 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 method-level @RabbitListener
.
- getTaskExecutor() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getThrowable() - Method in class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
-
- getThrowable() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
-
- getThrowable() - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
-
- getTimestamp() - Method in class org.springframework.amqp.core.MessageProperties
-
- getTimestamp() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
- getTimestamp() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getTransactionalResourceHolder(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder(ConnectionFactory, boolean, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- getTransactionAttribute() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getTransactionManager() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getTrustStore() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getTrustStore() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getTrustStoreAlgorithm() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getTrustStorePassphrase() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getTrustStorePassphrase() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getTrustStoreResource() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getTrustStoreType() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- getTrustStoreType() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getType() - Method in class org.springframework.amqp.core.AbstractExchange
-
- getType() - Method in class org.springframework.amqp.core.CustomExchange
-
- getType() - Method in class org.springframework.amqp.core.DirectExchange
-
- getType() - Method in interface org.springframework.amqp.core.Exchange
-
The type of the exchange.
- getType() - Method in class org.springframework.amqp.core.FanoutExchange
-
- getType() - Method in class org.springframework.amqp.core.HeadersExchange
-
- getType() - Method in class org.springframework.amqp.core.MessageProperties
-
- getType() - Method in class org.springframework.amqp.core.TopicExchange
-
- getType() - Method in class org.springframework.amqp.support.AmqpMessageHeaderAccessor
-
- getTypePrecedence() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Return the type precedence.
- getTypePrecedence() - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
Return the precedence.
- getTypePrecedence() - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
-
Get the type precedence.
- getUnconfirmed(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Gets unconfirmed correlation data older than age and removes them.
- getUnconfirmedCount() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Gets unconfirmed messages count.
- getUri() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getUser() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Return the user.
- 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
-
- getValue() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(Object, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValue(EvaluationContext, Class<T>) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueType() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueType(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueType(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueType(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueTypeDescriptor() - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueTypeDescriptor(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- getVirtualHost() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
- getVirtualHost() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- getXDeathHeader() - Method in class org.springframework.amqp.core.MessageProperties
-
Return the x-death header.
- GUnzipPostProcessor - Class in org.springframework.amqp.support.postprocessor
-
A post processor that uses a
GZIPInputStream
to decompress the
message body.
- GUnzipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
-
- GUnzipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.GUnzipPostProcessor
-
- GZipPostProcessor - Class in org.springframework.amqp.support.postprocessor
-
- GZipPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.GZipPostProcessor
-
- GZipPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.GZipPostProcessor
-
- ignoreDeclarationExceptions() - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Switch on ignore exceptions such as mismatched properties when declaring.
- ImmediateAcknowledgeAmqpException - Exception in org.springframework.amqp
-
Special exception for listener implementations that want to signal that the current
batch of messages should be acknowledged immediately (i.e.
- ImmediateAcknowledgeAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
-
- ImmediateAcknowledgeAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
-
- ImmediateAcknowledgeAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
-
- ImmediateRequeueAmqpException - Exception in org.springframework.amqp
-
- ImmediateRequeueAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
-
- ImmediateRequeueAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
-
- ImmediateRequeueAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
-
- ImmediateRequeueMessageRecoverer - Class in org.springframework.amqp.rabbit.retry
-
- 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
-
- init() - Method in class org.springframework.amqp.rabbit.config.RabbitNamespaceHandler
-
- initDefaultStrategies() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set up the default strategies.
- initGateway() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
Subclasses can override this for custom initialization behavior.
- initialize() - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Initialize the admin.
- initialize() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Declares all the exchanges, queues and bindings in the enclosing application context, if any.
- initialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Initialize this container.
- initializeConsumers() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- initializeContainer(C, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Further initialize the specified container.
- initializeContainer(DirectMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
- initializeContainer(SimpleMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- initializeProxy(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- INSTANCE - Static variable in class org.springframework.amqp.utils.JavaUtils
-
The singleton instance of this utility class.
- internal() - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Set the internal flag.
- InvocationData(MethodInvocation, Object) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
-
- InvocationData(MethodInvocation, Throwable) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
-
- InvocationResult - Class in org.springframework.amqp.rabbit.listener.adapter
-
The result of a listener method invocation.
- InvocationResult(Object, Expression, Type) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
-
- 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(MethodInvocation) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- invokeErrorHandler(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Invoke the registered ErrorHandler, if any.
- invokeListener(Channel, Message) - 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.listener.ActiveObjectCounter
-
- isAddMdcAsHeaders() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- isAlwaysRequeueWithTxManagerRollback() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isAttributeDefined(Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Checks the attribute to see if it is defined in the given element.
- isAutoAck() - Method in enum org.springframework.amqp.core.AcknowledgeMode
-
- 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
-
- isBrokerAndManagementRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- isBrokerAndManagementRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this
template's Channel handling and not by an external transaction coordinator.
- isChannelLocallyTransacted() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this
listener container's Channel handling and not by an external transaction coordinator.
- isChannelTransacted() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- isChannelTransactional(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Determine whether the given RabbitMQ Channel is transactional, that is, bound to the current thread by Spring's
transaction facilities.
- isConfirmListener() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
-
- isConfirmListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- isConfirmSelected() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
-
Return true if confirms are selected on this channel.
- isContentLengthSet() - Method in class org.springframework.amqp.core.MessageProperties
-
- 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.
- isDeclareExchange() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- isDefaultRequeueRejected() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Return the default requeue rejected.
- isDelayed() - Method in class org.springframework.amqp.core.AbstractExchange
-
- isDelayed() - Method in interface org.springframework.amqp.core.Exchange
-
Is a delayed message exchange; currently requires a broker plugin.
- isDeliveryTagSet() - Method in class org.springframework.amqp.core.MessageProperties
-
- isDestinationQueue() - Method in class org.springframework.amqp.core.Binding
-
- isDurable() - Method in class org.springframework.amqp.core.AbstractExchange
-
- isDurable() - Method in interface org.springframework.amqp.core.Exchange
-
A durable exchange will survive a server restart.
- isDurable() - Method in class org.springframework.amqp.core.Queue
-
A durable queue will survive a server restart.
- isDurable() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- isExchangeDeclarationFailure(Exception) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Return true if there is a ShutdownSignalException
in the cause tree and its
reason is "COMMAND_INVALID" and the operation being performed was exchangeDeclare.
- isExclusive() - Method in class org.springframework.amqp.core.Queue
-
True if the server should only send messages to the declarer's connection.
- isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Return whether the consumers should be exclusive.
- isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- isExclusiveUseChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Return true if the ShutdownSignalException
reason is AMQP.Channel.Close
and the operation that failed was basicConsumer and the failure text contains
"exclusive".
- isExistingTransaction(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- isExposeListenerChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
-
- isFatal(Throwable) - Method in interface org.springframework.amqp.rabbit.listener.FatalExceptionStrategy
-
- isFatal() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
-
- isFinalRetryForMessageWithNoId() - Method in class org.springframework.amqp.core.MessageProperties
-
- isForceCloseChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Force close the channel if the consumer threads don't respond to a shutdown.
- isFrozen() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Deprecated.
- isGenerateId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- 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.
- 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
-
- 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
-
- isOpen() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Flag to indicate the status of the connection.
- isOpen() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- isOpen() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
True if the connection is open.
- isPassiveDeclarationChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Return true if the ShutdownSignalException
reason is AMQP.Channel.Close
and the operation that failed was exchangeDeclare or queueDeclare.
- isPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Gets and removes a ThreadLocal indicating the channel MUST be physically closed.
- isPossibleAuthenticationFailureFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isPossibleAuthenticationFailureFatalSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
Return true if publisher confirms are enabled.
- isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelConnectionFactory
-
Deprecated.
- 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.
- isPublisherReturns() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelConnectionFactory
-
Deprecated.
- 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(Throwable) - Static method in class org.springframework.amqp.rabbit.listener.ContainerUtils
-
- isReleaseAfterCompletion() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Whether the resources should be released after transaction completion.
- 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- isRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- isRunning() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Determine whether this container is currently running, that is, whether it has been started and not stopped yet.
- isRunning() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- isRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Ensure the broker is running and has a empty queue(s) with the specified name(s) in the
default exchange.
- 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.
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- isSingleton() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- isSkipServerCertificateValidation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not Server Side certificate has to be validated or not.
- isStatefulRetryFatalWithNullMessageId() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isSynchedLocalTransactionAllowed() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Return whether to allow for a local RabbitMQ transaction that is synchronized with a Spring-managed
transaction (where the main transaction might be a JDBC-based one for a specific DataSource, for example),
with the RabbitMQ transaction committing right after the main transaction.
- isTransactional() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
-
Return whether this channel has transactions enabled txSelect()
.
- isTransactionAllowed() - Method in enum org.springframework.amqp.core.AcknowledgeMode
-
- isUp() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- isUsePublisherConnection() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
True if separate publisher connection(s) are used.
- isUserCauseFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
-
Subclasses can override this to add custom exceptions.
- isUseSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- isUseSsl() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- isVerifyHostname() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Return true (default) if TLS hostname verification is enabled.
- isWritable(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- isWritable(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- isWritable(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- RABBIT_EMPTY_STRING_ARGUMENTS_PROPERTY - Static variable in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- RABBIT_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
-
The bean name of the internally managed Rabbit listener annotation processor.
- RABBIT_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
-
The bean name of the internally managed Rabbit listener endpoint registry.
- RabbitAccessor - Class in org.springframework.amqp.rabbit.connection
-
- RabbitAccessor() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- RabbitAdmin - Class in org.springframework.amqp.rabbit.core
-
RabbitMQ implementation of portable AMQP administrative operations for AMQP >= 0.9.1.
- RabbitAdmin(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- RabbitAdmin(RabbitTemplate) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- RabbitAdminEvent - Class in org.springframework.amqp.rabbit.core
-
Base class for admin events.
- RabbitAdminEvent(Object) - Constructor for class org.springframework.amqp.rabbit.core.RabbitAdminEvent
-
- RabbitAvailable - Annotation Type in org.springframework.amqp.rabbit.junit
-
Test classes annotated with this will not run if there is no broker on localhost.
- RabbitAvailableCondition - Class in org.springframework.amqp.rabbit.junit
-
JUnit5 ExecutionCondition
.
- RabbitAvailableCondition() - Constructor for class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
-
- RabbitBootstrapConfiguration - Class in org.springframework.amqp.rabbit.annotation
-
- RabbitBootstrapConfiguration() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
-
- RabbitConnectionFactoryBean - Class in org.springframework.amqp.rabbit.connection
-
Factory bean to create a RabbitMQ ConnectionFactory, delegating most setter methods and
optionally enabling SSL, with or without certificate validation.
- RabbitConnectionFactoryBean() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- RabbitConverterFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
-
- RabbitExceptionTranslator - Class in org.springframework.amqp.rabbit.support
-
Translates Rabbit Exceptions to the
AmqpException
class
hierarchy.
- RabbitFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitFuture
-
- RabbitGatewaySupport - Class in org.springframework.amqp.rabbit.core
-
Convenient super class for application classes that need RabbitMQ access.
- RabbitGatewaySupport() - Constructor for class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
- RabbitHandler - Annotation Type in org.springframework.amqp.rabbit.annotation
-
Annotation that marks a method to be the target of a Rabbit message
listener within a class that is annotated with
RabbitListener
.
- RabbitListener - Annotation Type in org.springframework.amqp.rabbit.annotation
-
- RabbitListenerAnnotationBeanPostProcessor - Class in org.springframework.amqp.rabbit.annotation
-
Bean post-processor that registers methods annotated with
RabbitListener
to be invoked by a AMQP message listener container created under the cover
by a
RabbitListenerContainerFactory
according to the parameters of the annotation.
- RabbitListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- RabbitListenerConfigurationSelector - Class in org.springframework.amqp.rabbit.annotation
-
- RabbitListenerConfigurationSelector() - Constructor for class org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurationSelector
-
- RabbitListenerConfigurer - Interface in org.springframework.amqp.rabbit.annotation
-
Optional interface to be implemented by Spring managed bean willing
to customize how Rabbit listener endpoints are configured.
- RabbitListenerConfigUtils - Class in org.springframework.amqp.rabbit.config
-
Configuration constants for internal sharing across subpackages.
- RabbitListenerConfigUtils() - Constructor for class org.springframework.amqp.rabbit.config.RabbitListenerConfigUtils
-
- RabbitListenerContainerFactory<C extends MessageListenerContainer> - Interface in org.springframework.amqp.rabbit.listener
-
- RabbitListenerEndpoint - Interface in org.springframework.amqp.rabbit.listener
-
Model for a Rabbit listener endpoint.
- RabbitListenerEndpointRegistrar - Class in org.springframework.amqp.rabbit.listener
-
- RabbitListenerEndpointRegistrar() - Constructor for class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- RabbitListenerEndpointRegistry - Class in org.springframework.amqp.rabbit.listener
-
- RabbitListenerEndpointRegistry() - Constructor for class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- RabbitListenerErrorHandler - Interface in org.springframework.amqp.rabbit.listener.api
-
An error handler which is called when a {code @RabbitListener} method
throws an exception.
- RabbitListeners - Annotation Type in org.springframework.amqp.rabbit.annotation
-
Container annotation that aggregates several
RabbitListener
annotations.
- RabbitListenerTest - Annotation Type in org.springframework.amqp.rabbit.test
-
Annotate a @Configuration
class with this to enable proxying
@RabbitListener
beans to capture arguments and result (if any).
- RabbitListenerTestBootstrap - Class in org.springframework.amqp.rabbit.test
-
- RabbitListenerTestBootstrap() - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestBootstrap
-
- RabbitListenerTestHarness - Class in org.springframework.amqp.rabbit.test
-
- RabbitListenerTestHarness(AnnotationMetadata) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness
-
- RabbitListenerTestHarness.InvocationData - Class in org.springframework.amqp.rabbit.test
-
- RabbitListenerTestSelector - Class in org.springframework.amqp.rabbit.test
-
- RabbitListenerTestSelector() - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestSelector
-
- RabbitManagementTemplate - Class in org.springframework.amqp.rabbit.core
-
- RabbitManagementTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
Construct a template using uri "localhost:15672/api/" and user guest/guest.
- RabbitManagementTemplate(Client) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
Construct a template using the supplied client.
- RabbitManagementTemplate(String) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
Construct a template using the supplied uri.
- RabbitManagementTemplate(String, String, String) - Constructor for class org.springframework.amqp.rabbit.core.RabbitManagementTemplate
-
Deprecated.
Construct a template using the supplied uri.
- RabbitMessageFuture(String, Message) - Constructor for class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitMessageFuture
-
- RabbitMessageOperations - Interface in org.springframework.amqp.rabbit.core
-
- RabbitMessagingTemplate - Class in org.springframework.amqp.rabbit.core
-
- RabbitMessagingTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
Constructor for use with bean properties.
- RabbitMessagingTemplate(RabbitTemplate) - Constructor for class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- RabbitNamespaceHandler - Class in org.springframework.amqp.rabbit.config
-
Namespace handler for Rabbit.
- RabbitNamespaceHandler() - Constructor for class org.springframework.amqp.rabbit.config.RabbitNamespaceHandler
-
- RabbitNamespaceUtils - Class in org.springframework.amqp.rabbit.config
-
- RabbitOperations - Interface in org.springframework.amqp.rabbit.core
-
Rabbit specific methods for Amqp functionality.
- RabbitOperations.OperationsCallback<T> - Interface in org.springframework.amqp.rabbit.core
-
Callback for using the same channel for multiple RabbitTemplate
operations.
- RabbitResourceHolder - Class in org.springframework.amqp.rabbit.connection
-
Rabbit resource holder, wrapping a RabbitMQ Connection and Channel.
- RabbitResourceHolder() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Create a new RabbitResourceHolder that is open for resources to be added.
- RabbitResourceHolder(Channel, boolean) - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Construct an instance for the channel.
- RabbitTemplate - Class in org.springframework.amqp.rabbit.core
-
Helper class that simplifies synchronous RabbitMQ access (sending and receiving messages).
- RabbitTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Convenient constructor for use with setter injection.
- RabbitTemplate(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Create a rabbit template with default strategies and settings.
- RabbitTemplate.ConfirmCallback - Interface in org.springframework.amqp.rabbit.core
-
A callback for publisher confirmations.
- RabbitTemplate.ReturnCallback - Interface in org.springframework.amqp.rabbit.core
-
A callback for returned messages.
- RabbitTemplate.TemplateConsumer - Class in org.springframework.amqp.rabbit.core
-
- RabbitTransactionManager - Class in org.springframework.amqp.rabbit.transaction
-
- RabbitTransactionManager() - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
Create a new RabbitTransactionManager for bean-style usage.
- RabbitTransactionManager(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
Create a new RabbitTransactionManager, given a ConnectionFactory.
- RabbitUtils - Class in org.springframework.amqp.rabbit.connection
-
- RabbitUtils() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- RAW_MESSAGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
The received raw message before conversion; this header usually only appears in
an
ErrorMessage
.
- receive() - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue.
- receive(String) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a specific queue.
- receive(long) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message from a default queue, waiting up to the specified wait time if
necessary for a message to become available.
- receive(String, long) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message from a specific queue, waiting up to the specified wait time if
necessary for a message to become available.
- receive() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receive(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receive(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receive(String, long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert() - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue and convert it to a Java
object.
- receiveAndConvert(String) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a specific queue and convert it to a Java
object.
- receiveAndConvert(long) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue and convert it to a Java
object.
- receiveAndConvert(String, long) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a specific queue and convert it to a Java
object.
- receiveAndConvert(ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue and convert it to a Java
object.
- receiveAndConvert(String, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a specific queue and convert it to a Java
object.
- receiveAndConvert(long, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue and convert it to a Java
object.
- receiveAndConvert(String, long, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a specific queue and convert it to a Java
object.
- receiveAndConvert() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(String, long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(String, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(long, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(String, long, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(ReceiveAndReplyCallback<R, S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from a default queue, invoke provided
ReceiveAndReplyCallback
and send reply message, if the
callback
returns one, to the
replyTo
Address
from
MessageProperties
or to default exchange
and default routingKey.
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from provided queue, invoke provided
ReceiveAndReplyCallback
and send reply message, if the
callback
returns one, to the
replyTo
Address
from
MessageProperties
or to default exchange
and default routingKey.
- receiveAndReply(ReceiveAndReplyCallback<R, S>, String, String) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from default queue, invoke provided
ReceiveAndReplyCallback
and send reply message, if the
callback
returns one, to the provided
exchange
and
routingKey
.
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>, String, String) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Receive a message if there is one from provided queue, invoke provided
ReceiveAndReplyCallback
and send reply message, if the
callback
returns one, to the provided
exchange
and
routingKey
.
- receiveAndReply(ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
- receiveAndReply(ReceiveAndReplyCallback<R, S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(ReceiveAndReplyCallback<R, S>, String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>, String, String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndReply(String, ReceiveAndReplyCallback<R, S>, ReplyToAddressCallback<S>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- ReceiveAndReplyCallback<R,S> - Interface in org.springframework.amqp.core
-
To be used with the receive-and-reply methods of
AmqpTemplate
as processor for inbound object and producer for outbound object.
- ReceiveAndReplyMessageCallback - Interface in org.springframework.amqp.core
-
- RECEIVED_DELAY - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RECEIVED_DELIVERY_MODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RECEIVED_EXCHANGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RECEIVED_ROUTING_KEY - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RECEIVED_USER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.ImmediateRequeueMessageRecoverer
-
- recover(Message, Throwable) - Method in interface org.springframework.amqp.rabbit.retry.MessageRecoverer
-
Callback for message that was consumed but failed all retry attempts.
- recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
-
- recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- recoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply a Message recoverer - default is to log and discard after retry is exhausted.
- redeclareElementsIfNecessary() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- REDELIVERED - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- REF_ATTRIBUTE - Static variable in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
- registerAllEndpoints() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.amqp.rabbit.annotation.RabbitBootstrapConfiguration
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestBootstrap
-
- registerConsumerChannel(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
-
If a listener container is configured to use a RabbitTransactionManager, the
consumer's channel is registered here so that it is used as the bound resource
when the transaction actually starts.
- registerDeliveryTag(ConnectionFactory, Channel, Long) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
- registerEndpoint(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- registerEndpoint(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- registerListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- registerListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>, boolean) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- RejectAndDontRequeueRecoverer - Class in org.springframework.amqp.rabbit.retry
-
MessageRecover that causes the listener container to reject
the message without requeuing.
- RejectAndDontRequeueRecoverer() - Constructor for class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
-
- release(T) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- releaseBatches() - Method in interface org.springframework.amqp.rabbit.core.support.BatchingStrategy
-
Release batch(es), perhaps due to a timeout.
- releaseBatches() - Method in class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
-
- releaseConsumerFor(DirectReplyToMessageListenerContainer.ChannelHolder, boolean, String) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
Release the consumer associated with the channel for reuse.
- releaseResources(RabbitResourceHolder) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
- releaseSub(long, TimeUnit) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
-
- RemoteInvocationAwareMessageConverterAdapter - Class in org.springframework.amqp.support.converter
-
A delegating adapter that unwraps
RemoteInvocationResult
after invoking
the delegate to convert from a message.
- RemoteInvocationAwareMessageConverterAdapter() - Constructor for class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
-
- RemoteInvocationAwareMessageConverterAdapter(MessageConverter) - Constructor for class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
-
- removeAfterReceivePostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- removeAfterReceivePostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- removeBeforePublishPostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- removeBinding(Binding) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Remove a binding of a queue to an exchange.
- removeBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- removeBlockedListener(BlockedListener) - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Remove a BlockedListener
.
- removeBlockedListener(BlockedListener) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- removeChannel(AutorecoveringChannel) - Static method in class org.springframework.amqp.rabbit.connection.ClosingRecoveryListener
-
- removeConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- removeConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
- removeDecompressor(String) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
- removeDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- removeDelegate(String) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
Remove the delegate for the content type.
- removeHeader(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- removeHeaders() - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Remove queue(s) from this container's list of queues.
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Remove queues from this container's list of queues.
- removeQueueOrTagToMethodName(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Remove the mapping of a queue name or consumer tag to a method name.
- removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Remove queue(s) from this container's list of queues.
- removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Remove queues from this container's list of queues.
- removeReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- removeShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- removeTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- removeTestQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- REPLY_TO - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- ReplyExpressionRoot(Message, Object, Object) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener.ReplyExpressionRoot
-
- ReplyFailureException - Exception in org.springframework.amqp.rabbit.listener.adapter
-
Exception to be thrown when the reply of a message failed to be sent.
- ReplyFailureException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.adapter.ReplyFailureException
-
- ReplyingMessageListener<T,R> - Interface in org.springframework.amqp.rabbit.listener.adapter
-
- replyTimedOut(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Subclasses can implement this to be notified that a reply has timed out.
- ReplyToAddressCallback<T> - Interface in org.springframework.amqp.core
-
- RepublishMessageRecoverer - Class in org.springframework.amqp.rabbit.retry
-
MessageRecoverer
implementation that republishes recovered messages
to a specified exchange with the exception stack trace stored in the
message header x-exception.
- RepublishMessageRecoverer(AmqpTemplate) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- RepublishMessageRecoverer(AmqpTemplate, String) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- RepublishMessageRecoverer(AmqpTemplate, String, String) - Constructor for class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- reset(List<ChannelProxy>, List<ChannelProxy>, Map<Channel, ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- reset() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- resetConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Close the connection(s).
- resolveParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
-
- retrieveHeader(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- retrieveHeaderAsString(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- RetryInterceptorBuilder<B extends RetryInterceptorBuilder<B,T>,T extends MethodInterceptor> - Class in org.springframework.amqp.rabbit.config
-
Simplified facade to make it easier and simpler to build a
StatefulRetryOperationsInterceptor
or
(stateless) RetryOperationsInterceptor
by providing a fluent interface to defining the behavior on error.
- RetryInterceptorBuilder() - Constructor for class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
- RetryInterceptorBuilder.StatefulRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
-
Builder for a stateful interceptor.
- RetryInterceptorBuilder.StatelessRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
-
Builder for a stateless interceptor.
- retryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply the retry operations - once this is set, other properties can no longer be set; can't
be set if other properties have been applied.
- retryPolicy(RetryPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply the retry policy - cannot be used if a custom retry template has been provided, or the max attempts or
back off options or policy have been applied.
- RETURN_EXCHANGE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RETURN_LISTENER_CORRELATION_KEY - Static variable in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Header used to determine which listener to invoke for a returned message.
- RETURN_REPLY_CODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RETURN_REPLY_TEXT - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RETURN_ROUTING_KEY - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- RETURNED_MESSAGE_CORRELATION_KEY - Static variable in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Header used to locate a pending confirm to which to attach a returned message.
- returnedMessage(Message, int, String, String, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- returnedMessage(Message, int, String, String, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnCallback
-
Returned message callback.
- revoke(Channel) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
-
When called, this listener should remove all references to the
channel - it will no longer be invoked by the channel.
- revoke(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- rollbackAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- rollbackIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- rollbackOn(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ListenerFailedRuleBasedTransactionAttribute
-
- rollbackOnExceptionIfNecessary(Throwable) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Perform a rollback, handling rollback exceptions properly.
- RoutingConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
-
Implementations select a connection factory based on a supplied key.
- rpc(Method) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- run() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.EventSender
-
- run() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.EventSender
-
- RUN_LONG_INTEGRATION_TESTS - Static variable in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
-
- saslConfig - Variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
-
SaslConfig.
- saslConfig - Variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
SaslConfig.
- selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurationSelector
-
- selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestSelector
-
- send(Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a default exchange with a default routing key.
- send(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a default exchange with a specific routing key.
- send(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a specific exchange with a specific routing key.
- send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
-
- send(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Send a message to a specific exchange with a specific routing key.
- send(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- send(String, String, Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Send a message to a specific exchange with a specific routing key.
- send(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- send(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- send(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the default exchange with the default routing key.
- sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the default exchange with the supplied routing key.
- sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the supplied exchange and routing key.
- sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- sendAndReceive(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Send a request message to a specific exchange with a specific routing key and
wait for the reply.
- sendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendEvent(AmqpAppender.Event, Map<?, ?>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
- sendResponse(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Send the given response message to the given destination.
- SendRetryContextAccessor - Class in org.springframework.amqp.support
-
Type safe accessor for retried message sending.
- sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
-
- SerializationUtils - Class in org.springframework.amqp.utils
-
Static utility to help with serialization.
- serialize(Object) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
Serialize the object provided.
- SerializerMessageConverter - Class in org.springframework.amqp.support.converter
-
- SerializerMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SerializerMessageConverter
-
- setAbbreviation(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Flag controlling the behaviour of the container with respect to message acknowledgement.
- setAckTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
An approximate timeout; when
messagesPerAck
is
greater than 1, and this time elapses since the last ack, the pending acks will be
sent either when the next message arrives, or a short time later if no additional
messages arrive.
- setAckTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
An approximate timeout; when
messagesPerAck
is
greater than 1, and this time elapses since the last ack, the pending acks will be
sent either when the next message arrives, or a short time later if no additional
messages arrive.
- setActualName(String) - Method in class org.springframework.amqp.core.Queue
-
Set the name from the DeclareOk.
- setAddMdcAsHeaders(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set addresses for clustering.
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setAddressResolver(AddressResolver) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- setAdminPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the password for the management REST API connection default "guest".
- setAdminsThatShouldDeclare(Object...) - Method in class org.springframework.amqp.core.AbstractDeclarable
-
The AmqpAdmin
s that should declare this object; default is
all admins.
- setAdminsThatShouldDeclare(AmqpAdmin...) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setAdminUri(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the uri for the REST API.
- setAdminUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the user for the management REST API connection default "guest".
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Public setter for the
Advice
to apply to listener executions.
- setAfterAckCallback(Consumer<Channel>) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Set a callback to be invoked after the ack/nack has been handled.
- setAfterAckCallback(Consumer<Channel>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set post processors which will be applied after the Message is received.
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set a
MessagePostProcessor
that will be invoked immediately after a
Channel#basicGet()
and before any message conversion is performed.
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setAlwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to always requeue on transaction rollback with an external
TransactionManager
.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the
AmqpAdmin
, used to declare any auto-delete queues, bindings
etc when the container is started.
- setAmqpMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- setAmqpTemplate(AmqpTemplate) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
The AMQP template to be used for sending messages and receiving results.
- setAmqpTemplate(AmqpTemplate) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
The AMQP template to use for sending the return value.
- setAppId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setAppId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setAppIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- setApplicationId(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to automatically declare elements (queues, exchanges, bindings)
in the application context during container start().
- setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setAutomaticRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set to true to enable amqp-client automatic recovery.
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set whether to automatically start the container after initialization.
- setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Override the default autoStartup property.
- setBackOffExecution(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the
BackOffExecution
to use for the recovery in the
SimpleMessageListenerContainer
.
- setBean(Object) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the object instance that should manage this endpoint.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.RemoteInvocationAwareMessageConverterAdapter
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setBeanResolver(BeanResolver) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a bean resolver for runtime SpEL expressions.
- setBeforePublishPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set
MessagePostProcessor
s that will be invoked immediately before invoking
Channel#basicPublish()
, after all other processing, except creating the
AMQP.BasicProperties
from
MessageProperties
.
- setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set post processors that will be applied before sending replies; added to each
message listener adapter.
- setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set post processors that will be applied before sending replies.
- setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setCause(String) - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
When the confirmation is nacked, set the cause when available.
- setChannelAwareMessageListener(ChannelAwareMessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setChannelAwareMessageListener(ChannelAwareMessageListener) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
Deprecated.
- setChannelCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
The number of channels to maintain in the cache.
- setChannelCheckoutTimeout(long) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Sets the channel checkout timeout.
- setChannelListeners(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setChannelRpcTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setChannelTransacted(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Flag to indicate that channels created by this component will be transactional.
- setCharset(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setClassMapper(ClassMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set additional client connection properties to be added to the rabbit connection,
with the form key:value[,key:value]...
.
- setClientProperties(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Add custom client properties.
- setCloseExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Set the strategy for logging close exceptions; by default, if a channel is closed due to a failed
passive queue declaration, it is logged at debug level.
- setCloseTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
How long to wait (milliseconds) for a response to a connection close
operation from the broker; default 30000 (30 seconds).
- setClusterId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setClusterId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setClusterIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setCodebaseUrl(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
Set the codebase URL to download classes from if not found locally.
- setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the concurrency of this endpoint; usually overrides any concurrency
settings on the container factory.
- setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Specify concurrency limits via a "lower-upper" String, e.g.
- setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Specify the number of concurrent consumers to create.
- setConfirmCallback(RabbitTemplate.ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setConnectionCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Set the ConnectionFactory to use for obtaining RabbitMQ
Connections
.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
Set the Rabbit connection factory to be used by the gateway.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- setConnectionLimit(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Set the connection limit when using cache mode CONNECTION.
- setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setConnectionName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set a name for the connection which will appear on the RabbitMQ Admin UI.
- setConnectionNameStrategy(ConnectionNameStrategy) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setConnectionThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set the
ThreadFactory
on the underlying rabbit connection factory.
- setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConsecutiveActiveTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConsecutiveIdleTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set consumer arguments.
- setConsumerQueue(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setConsumersPerQueue(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Each queue runs in its own consumer; set this property to create multiple
consumers for each queue.
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Each queue runs in its own consumer; set this property to create multiple
consumers for each queue.
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- setConsumerStartTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
When starting a consumer, if this time (ms) elapses before the consumer starts, an
error log is written; one possible cause would be if the
taskExecutor
has
insufficient threads to support the container concurrency.
- setConsumerTag(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setContainerConfigurer(Consumer<C>) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
A
Consumer
that is invoked to enable setting other container properties not
exposed by this container factory.
- setContainerFactory(RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setContentEncodingIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setContentLength(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setContentLength(long) - Method in class org.springframework.amqp.core.MessageProperties
-
- setContentLengthIfAbsent(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setContentType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setContentType(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setContentType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setContentType(String) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the contentType to be used by this message converter.
- setContentTypeIfAbsentOrDefault(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setCopyProperties(boolean) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Flag to indicate if
MessageProperties
should be used as is or cloned for new message
after compression.
- setCorrelationDataPostProcessor(CorrelationDataPostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the correlation id.
- setCorrelationIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setCorrelationKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
If set to 'correlationId' (default) the correlationId property
will be used; otherwise the supplied key will be used.
- setCreateMessageIds(boolean) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
-
Flag to indicate that new messages should have unique identifiers added to their properties before sending.
- setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setDeBatchingEnabled(Boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
Determine whether or not the container should de-batch batched
messages (true) or call the listener with the batch (false).
- setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Determine whether or not the container should de-batch batched
messages (true) or call the listener with the batch (false).
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the number of retries after passive queue declaration fails.
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set the number of retries after passive queue declaration fails.
- setDeclareCollections(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setDecompressors(Map<String, MessagePostProcessor>) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
Replace all the decompressors.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Specify the default charset to use when converting to or from text-based
Message body content.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
Specify the default charset to use when converting to or from text-based Message body content.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
Specify the default charset to use when converting to or from text-based
Message body content.
- setDefaultConsumer(Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- setDefaultListenerMethod(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Specify the name of the default listener method to delegate to, for the case where no specific listener method
has been determined.
- setDefaultMapClass(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Set the type of
Map
to use.
- setDefaultReceiveQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default queue to receive messages from when none is specified explicitly.
- setDefaultRequeueRejected(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the default behavior when a message is rejected, for example because the listener
threw an exception.
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set to the value of this listener's container equivalent property.
- setDefaultTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- setDefaultType(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- setDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the x-delay header.
- setDelayed(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
-
Set the delayed flag.
- setDelegate(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set a target object to delegate message listening to.
- setDelegates(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- setDelegates(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- setDelegates(Map<String, MessageConverter>) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
-
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
-
- setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
Specify a
MessageDeliveryMode
to set into the message to republish
if the message doesn't have it already.
- setDeliveryModeIfAbsentOrDefault(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setDeliveryTag(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setDeliveryTag(long) - Method in class org.springframework.amqp.core.MessageProperties
-
- setDeliveryTagIfAbsent(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setDeserializer(Deserializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
The deserializer to use for converting from message body to Java object.
- setDestinationExchange(Exchange) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setDestinationQueue(Queue) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setDiscardFatalsWithXDeath(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
Set to false to disable the (now) default behavior of logging and discarding
messages that cause fatal exceptions and have an `x-death` header; which
usually means that the message has been republished after previously being
sent to a DLQ.
- setDurable(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setEnableConfirms(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set to true to enable publisher confirms.
- setEnableHostnameVerification(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Enable server hostname verification for TLS connections.
- setEncoder(Encoder<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The encoding to use when converting between byte arrays and Strings in message properties.
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
The encoding to use when inter-converting between byte arrays and Strings in
message properties.
- setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
- setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
- setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
-
- setEnvironmentVariableOverrides(Map<String, String>) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set environment variable overrides for host, port etc.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
- setErrorHandler(RabbitListenerErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
- setErrorHandlerLoggerName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name (category) of the logger used to log exceptions thrown by the error handler.
- setErrorRoutingKeyPrefix(String) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- setExceptionHandler(ExceptionHandler) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setExchange(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default exchange to use for send operations when none is specified.
- setExchangeName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setExchangeType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true for an exclusive consumer.
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set if a single consumer in the container will have exclusive use of the
queues, preventing other consumers from receiving messages from the
queue(s).
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set to true for an exclusive consumer - if true, the concurrency must be 1.
- setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setExecutor(Executor) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Provide an Executor for
use by the Rabbit ConnectionFactory when creating connections.
- setExpiration(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setExpiration(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setExpirationIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setExplicitDeclarationsOnly(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set to true to only declare
Declarable
beans that are explicitly configured
to be declared by this admin.
- setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setFailedDeclarationRetryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setFinalRetryForMessageWithNoId(boolean) - Method in class org.springframework.amqp.core.MessageProperties
-
- setForceCloseChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to force close the channel if the consumer threads don't respond to a
shutdown.
- setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setGroup(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the group for the corresponding listener container.
- setHandlerAdapter(HandlerAdapter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
-
- setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageProperties
-
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
-
Set the
AmqpHeaderMapper
implementation to use to map the standard
AMQP headers.
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
-
Set the
AmqpHeaderMapper
to use to map AMQP headers to and from
standard message headers.
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setHostName(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- setId(String) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Set the correlation id.
- setId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Set a map of type Ids (in the
"__TypeId__" header) to
classes.
- setIdleEventInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
How often to publish idle container events.
- setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setIgnoreContentType(boolean) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
Flag to signal that the content type should be ignored and the deserializer used irrespective if it is a text
message.
- setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
-
Set to true to ignore exceptions such as mismatched properties when declaring.
- setIgnoreDeclarationExceptions(Boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setIncludeCallerData(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
If true, the caller data will be available in the target AMQP message.
- setInferredArgumentType(Type) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the inferred target argument type when using a method-level
@RabbitListener
.
- setInternal(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
-
Set the internal flag.
- setJavaTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
- setKeyStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store resource (e.g.
- setKeyStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setKeyStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm used when creating the key store, default SunX509
.
- setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setKeyStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a Resource pointing to the key store.
- setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setLayout(Layout<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setLenientFallback(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- setLevel(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
-
Set the deflater compression level.
- setListenerId(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setListenerId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setLocallyTransacted(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
True if the channel is locally transacted.
- setLookupKeyQualifier(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a qualifier that will prefix the connection factory lookup key; default none.
- setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set the mandatory flag when sending messages; only applies if a
returnCallback
had been provided.
- setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setMandatoryPublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
- setMarshaller(Marshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the
Marshaller
to be used by this message converter.
- setMasterLocator(String) - Method in class org.springframework.amqp.core.Queue
-
Set the master locator strategy argument for this queue.
- setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMaxConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Sets an upper limit to the number of consumers; defaults to 'concurrentConsumers'.
- setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set the message converter for this template.
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the converter that will convert incoming Rabbit messages to listener method arguments, and objects returned
from listener methods back to Rabbit messages.
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
-
- setMessageConverter(MessageConverter) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
The preferred way for a container factory to pass a message converter
to the endpoint's adapter.
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
Set the message converter for this remote service.
- setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the message count.
- setMessageCountIfAbsent(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Set the
MessageHandlerMethodFactory
to use to configure the message
listener responsible to serve an endpoint detected by this processor.
- setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
- setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the
MessageHandlerMethodFactory
to use to configure the message
listener responsible to serve an endpoint detected by this processor.
- setMessageId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setMessageId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setMessageIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setMessageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
-
Set the
MessageListener
to invoke when a message matching
the endpoint is received.
- setMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
Deprecated.
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- setMessagesPerAck(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set the number of messages to receive before acknowledging (success).
- setMessagesPerAck(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set the number of messages to receive before acknowledging (success).
- setMethod(Method) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the method to invoke to process a message managed by this endpoint.
- setMetricsCollector(MetricsCollector) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setMismatchedQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Prevent the container from starting if any of the queues defined in the context have
mismatched arguments (TTL etc).
- setMissingQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
If all of the configured queue(s) are not available on the broker, this setting
determines whether the condition is fatal.
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
If all of the configured queue(s) are not available on the broker, this setting
determines whether the condition is fatal.
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If all of the configured queue(s) are not available on the broker, this setting
determines whether the condition is fatal.
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set how often to run a task to check for failed consumers and idle containers.
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set how often to run a task to check for failed consumers and idle containers.
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- setNewMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- setNioParams(NioParams) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setNoLocal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setNoLocal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true for an no-local consumer.
- setNoLocalReplyConsumer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set to true for a no-local consumer.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Set the order.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
Set the order.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
Set the order.
- setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
-
- setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the password for the amqp connection default "guest".
- setPassword(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setPayloadConverter(MessageConverter) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the phase in which this container should be started and stopped.
- setPhysicalCloseRequired(Channel, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Sets a ThreadLocal indicating the channel MUST be physically closed.
- setPort(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setPort(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setPort(int) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
- setPort(Integer) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setPossibleAuthenticationFailureFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setPossibleAuthenticationFailureFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setPrefetchCount(Integer) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Tell the broker how many messages to send to each consumer in a single request.
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
- setPriority(Integer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the priority of this endpoint.
- setPriorityIfAbsentOrDefault(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setPublisherChannelFactory(PublisherCallbackChannelFactory) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setPublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Use full publisher confirms, with correlation data and a callback for each message.
- setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setPublisherReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setPublishSequenceNumber(long) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the publish sequence number, if publisher confirms are enabled; set by the template.
- setQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name of the queue(s) to receive messages from.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the queue names to use.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
-
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setQueueOrTagToMethodName(Map<String, String>) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set the mapping of queue name or consumer tag to method name.
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name of the queue(s) to receive messages from.
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the queues to use.
- setRabbitAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setRabbitAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setRabbitOperations(RabbitOperations) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
- setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
- setReceiveConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setReceivedDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
When a delayed message exchange is used the x-delay header on a
received message contains the delay.
- setReceivedDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReceivedExchangeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReceivedRoutingKeyIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReceivedUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set the receive timeout - the future returned by the send and receive
methods will be canceled when this timeout expires.
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setReceiveTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Specify the receive timeout in milliseconds when using
receive()
methods (for
sendAndReceive()
methods, refer to
replyTimeout
.
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The time (in milliseconds) that a consumer should wait for data.
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the
BackOff
for interval between recovery attempts.
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add a RecoveryCallback
which is used for the retryTemplate.execute
.
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a RecoveryCallback
to invoke when retries are exhausted.
- setRecoveryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the interval between recovery attempts, in milliseconds.
- setRecoveryListener(RecoveryListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set a RecoveryListener
that will be added to each connection created.
- setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageProperties
-
- setRedeliveredIfAbsent(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the specified bean definition property with the reference to a bean.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition property corresponding to the specified attributeName with the reference to a bean
identified by the value of that attribute if the attribute is defined in the given element.
- setRejectManual(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
Set to false to NOT reject a fatal message when MANUAL ack mode is being used.
- setRemoteInvocationFactory(RemoteInvocationFactory) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
Set the RemoteInvocationFactory to use for this accessor.
- setReplyAddress(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
An address for replies; if not provided, a temporary exclusive, auto-delete queue will
be used for each reply, unless RabbitMQ supports 'amq.rabbitmq.reply-to' - see
https://www.rabbitmq.com/direct-reply-to.html
- setReplyErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
When using a direct reply-to container for request/reply operations, set an error
handler to be invoked when a reply delivery fails (e.g.
- setReplyPostProcessor(MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
- setReplyRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set a RecoveryCallback
to invoke when retries are exhausted.
- setReplyTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Specify the timeout in milliseconds to be used when waiting for a reply Message when using one of the
sendAndReceive methods.
- setReplyTo(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReplyTo(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageProperties
-
- setReplyToAddressIfAbsent(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setReplyToIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setRequestedChannelMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setRequestedFrameMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setRequestedHeartBeat(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setRequestedHeartbeat(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setRequeueOnRollback(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Set to true to requeue a message on rollback; default true.
- setResponseAddress(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the default replyTo address to use when sending response messages.
- setResponseExchange(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the exchange to use when sending response messages.
- setResponseRoutingKey(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the routing key to use when sending response messages.
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
When consuming multiple queues, set the interval between declaration attempts when only
a subset of the queues were available (milliseconds).
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
When consuming multiple queues, set the interval between declaration attempts when only
a subset of the queues were available (milliseconds).
- setRetryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set a RetryTemplate
to use when sending replies; added to each message
listener adapter.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set a retry template for auto declarations.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add a RetryTemplate
which will be used for all rabbit operations.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a RetryTemplate
to use when sending replies.
- setReturnCallback(RabbitTemplate.ReturnCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setReturnedMessage(Message) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Set a returned message for this correlation data.
- setReturnExceptions(boolean) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set whether exceptions thrown by the listener should be returned to the sender
using the normal replyTo/@SendTo
semantics.
- setReturnType(ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate.RabbitConverterFuture
-
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The value of a default routing key to use for send operations when none is specified.
- setRoutingKey(String) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
The routing key to send calls to the service with.
- setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setSaslConfig(SaslConfig) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setSaslConfig(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set the SaslConfig
.
- setSecureRandom(SecureRandom) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the secure random to use when initializing the
SSLContext
.
- setSendConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setSerializer(Serializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
The serializer to use for converting Java objects to message bodies.
- setSharedExecutor(ExecutorService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setShouldDeclare(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
-
Whether or not this object should be automatically declared
by any AmqpAdmin
.
- setShouldDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setShuffleAddresses(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
When
addresses
are provided and there is more than
one, set to true to shuffle the list before opening a new connection so that the
connection to the broker will be attempted in random order.
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
The time to wait for workers in milliseconds after the container is stopped.
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Use simple publisher confirms where the template simply waits for completion.
- setSkipServerCertificateValidation(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not Server Side certificate has to be validated or not.
- setSocketConfigurator(SocketConfigurator) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setSocketFactory(SocketFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm to use; default TLSv1.1.
- setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setSslPropertiesLocation(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setSslPropertiesLocation(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setStartConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setStatefulRetryFatalWithNullMessageId(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set whether a message with a null messageId is fatal for the consumer
when using stateful retry.
- setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setStopConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- setTargetBean(Object) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the target bean when using @RabbitListener
.
- setTargetConnectionFactories(Map<Object, ConnectionFactory>) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify the map of target ConnectionFactories, with the lookup key as key.
- setTargetMethod(Method) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the target method when using a method-level @RabbitListener
.
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set a task executor to use for async operations.
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a task executor for the container - used to create the consumers not at
runtime.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set the task scheduler to expire timed out futures.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set the task scheduler to use for the task that monitors idle containers and
failed consumers.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set the task scheduler to use for the task that monitors idle containers and
failed consumers.
- setThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageProperties
-
- setTimestampIfAbsent(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setTopologyRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set to true to enable amqp-client topology recovery.
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the transaction attribute to use when using an external transaction manager.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the transaction manager to use.
- setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Specify a set of packages to trust during deserialization.
- setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
Specify a set of packages to trust during deserialization.
- setTrustStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store resource (e.g.
- setTrustStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setTrustStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm used when creating the trust store, default SunX509
.
- setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setTrustStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a Resource pointing to the trust store.
- setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setTxSize(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTxSize(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- setTxSize(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Tells the container how many messages to process in a single transaction (if the
channel is transactional).
- setType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setType(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setType(ListenerContainerFactoryBean.Type) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- setTypeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Set the precedence for evaluating type information in message properties.
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
Set the precedence for evaluating type information in message properties.
- setUnmarshaller(Unmarshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
- setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
-
- setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setupListenerContainer(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
- setupListenerContainer(MessageListenerContainer) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
Setup the specified message listener container with the model
defined by this endpoint.
- setupMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setupMessageListener(MessageListener) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
-
Setup the message listener to use.
- setUpSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Override this method to take complete control over the SSL setup.
- setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setUri(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setUri(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setUri(URI) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setUseDirectReplyToContainer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setUseNio(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not the factory should be configured to use Java NIO.
- setUsePublisherConnection(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
To avoid deadlocked connections, it is generally recommended to use
a separate connection for publishers and consumers (except when a publisher
is participating in a consumer transaction).
- setUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the user for the amqp connection default "guest".
- setUserCorrelationId(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set to true to use correlation id provided by the message instead of generating
the correlation id for request/reply scenarios.
- setUserId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- setUserIdExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set an expression to be evaluated to set the userId message property if it
evaluates to a non-null value and the property is not already set in the
message to be sent.
- setUserIdExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set an expression to be evaluated to set the userId message property if it
evaluates to a non-null value and the property is not already set in the
message to be sent.
- setUserIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setUsername(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setUseSSL(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not the factory should be configured to use SSL.
- setUseSsl(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setUseTemporaryReplyQueues(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
By default, when the broker supports it and no
replyAddress
is provided, send/receive
methods will use Direct reply-to (https://www.rabbitmq.com/direct-reply-to.html).
- setValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- setValue(Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
-
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the specified bean definition property with the value of the attribute whose name is provided if that
attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition property corresponding to the specified attributeName with the value of that
attribute if it is defined in the given element.
- setVerifyHostname(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Enable server hostname verification for TLS connections.
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- setWhiteListPatterns(List<String>) - Method in class org.springframework.amqp.support.converter.WhiteListDeserializingMessageConverter
-
Set simple patterns for allowable packages/classes for deserialization.
- sharedConnectionEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Always use a shared Rabbit Connection.
- SharedConnectionNotInitializedException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.SharedConnectionNotInitializedException
-
Create a new SharedConnectionNotInitializedException.
- shouldDeclare() - Method in class org.springframework.amqp.core.AbstractDeclarable
-
- shouldDeclare() - Method in interface org.springframework.amqp.core.Declarable
-
Whether or not this object should be automatically declared
by any AmqpAdmin
.
- shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.QueueParser
-
- shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
-
- shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.QueueParser
-
- shouldRequeue(boolean, Throwable, Log) - Static method in class org.springframework.amqp.rabbit.listener.ContainerUtils
-
- shutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- ShutDownChannelListener - Interface in org.springframework.amqp.rabbit.connection
-
Functional sub interface enabling a lambda for the onShutDown method.
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
-
- SimpleAmqpHeaderMapper - Class in org.springframework.amqp.support
-
- SimpleAmqpHeaderMapper() - Constructor for class org.springframework.amqp.support.SimpleAmqpHeaderMapper
-
- SimpleBatchingStrategy - Class in org.springframework.amqp.rabbit.core.support
-
A simple batching strategy that supports only one exchange/routingKey; includes a batch
size, a batched message size limit and a timeout.
- SimpleBatchingStrategy(int, int, long) - Constructor for class org.springframework.amqp.rabbit.core.support.SimpleBatchingStrategy
-
- SimpleConnection - Class in org.springframework.amqp.rabbit.connection
-
Simply a Connection.
- SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- SimpleMessageConverter - Class in org.springframework.amqp.support.converter
-
Implementation of
MessageConverter
that can work with Strings, Serializable
instances, or byte arrays.
- SimpleMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SimpleMessageConverter
-
- SimpleMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
-
- SimpleMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Default constructor for convenient dependency injection via setters.
- SimpleMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Create a listener container from the connection factory (mandatory).
- SimplePropertyValueConnectionNameStrategy - Class in org.springframework.amqp.rabbit.connection
-
- SimplePropertyValueConnectionNameStrategy(String) - Constructor for class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
-
- SimpleRabbitListenerContainerFactory - Class in org.springframework.amqp.rabbit.config
-
- SimpleRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
- SimpleRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.config
-
- SimpleRabbitListenerEndpoint() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
-
- SimpleResourceHolder - Class in org.springframework.amqp.rabbit.connection
-
Central helper that manages resources per thread to be used by resource management
code.
- SimpleRoutingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
-
- SimpleRoutingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
-
- SmartMessageConverter - Interface in org.springframework.amqp.support.converter
-
- sort(Collection<MessagePostProcessor>) - Static method in class org.springframework.amqp.support.postprocessor.MessagePostProcessorUtils
-
- SPRING_AUTO_DECOMPRESS - Static variable in class org.springframework.amqp.core.MessageProperties
-
- SPRING_BATCH_FORMAT - Static variable in class org.springframework.amqp.core.MessageProperties
-
- SPRING_REPLY_CORRELATION - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- SPRING_REPLY_TO_STACK - Static variable in class org.springframework.amqp.support.AmqpHeaders
-
- start() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- start() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- start() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- start() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- start() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Start this container.
- start() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- start() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- start() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- stateful() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateful retry interceptor.
- StatefulRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateful retry interceptor for use in a message listener container, giving you
a large amount of control over the behaviour of a container when a listener fails.
- StatefulRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- stateless() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateless retry interceptor.
- StatelessRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateless retry interceptor for use in a message listener container, giving
you a large amount of control over the behaviour of a container when a listener fails.
- StatelessRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- stop() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
- stop() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
- stop() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
-
- stop() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- stop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Stop this container.
- stop() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- stop() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
-
- stop(long, TimeUnit, boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
-
- stop() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
- stringToSaslConfig(String, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Convert a String value to a SaslConfig
.
- supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
-
- suppressDeclaration() - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Switch to disable declaration of the exchange by any admin.
- SYSTEM - Static variable in class org.springframework.amqp.core.ExchangeTypes
-
System exchange.