- abort() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- abort(int, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- AbstractConnectionFactory - Class in org.springframework.amqp.rabbit.connection
-
- AbstractConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Create a new SingleConnectionFactory for the given target ConnectionFactory.
- AbstractDeclarable - Class in org.springframework.amqp.core
-
- AbstractDeclarable() - Constructor for class org.springframework.amqp.core.AbstractDeclarable
-
- 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 Exchange for bean usage.
- 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
-
- AbstractJavaTypeMapper - Class in org.springframework.amqp.support.converter
-
- AbstractJavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- AbstractJsonMessageConverter - Class in org.springframework.amqp.support.converter
-
- AbstractJsonMessageConverter() - Constructor for class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
- 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.
- 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
-
- AcknowledgeMode - Enum in org.springframework.amqp.core
-
- ActiveObjectCounter<T> - Class in org.springframework.amqp.rabbit.listener
-
- ActiveObjectCounter() - Constructor for class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- add(T) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- addAndStartConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- addArgument(String, Object) - Method in class org.springframework.amqp.core.AbstractExchange
-
- addChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addChannel(Channel, Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addChannelListener(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- addConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addConnection(Connection) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- addConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- addConstructorArgBooleanValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with the boolean value of that attribute if it is defined in
the given element or else uses the default provided.
- addConstructorArgParentRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with a reference to a bean with parent id equal to the
attribute if it is defined in the given element.
- addConstructorArgRefIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with a reference to a bean with id equal to the attribute if
it is defined in the given element.
- addConstructorArgValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition constructor argument with the value of that attribute if it is defined in the given
element.
- addDelegate(ChannelListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- addDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- addDeliveryTag(Channel, long) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- addFlowListener(FlowListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addHeader(MessageProperties, String, Class<?>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- addListener(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
-
Adds a
PublisherCallbackChannel.Listener
and returns a reference to
the pending confirms map for that listener's pending
confirms, allowing the Listener to
assess unconfirmed sends at any point in time.
- addListener(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
Add the listener and return the internal map of pending confirmations for that listener.
- addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
-
Adds a pending confirmation to this channel's map.
- addPendingConfirm(PublisherCallbackChannel.Listener, long, PendingConfirm) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- addQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Add queue(s) to this container's list of queues.
- 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 in the form
(exchangeType)://(exchange)/(routingKey)
- Address(String, String, String) - Constructor for class org.springframework.amqp.core.Address
-
Create an Address given the exchange type, exchange name and routing key.
- addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addTargetConnectionFactory(Object, ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
If
autoStartup
is set to true, registers a callback on the
ConnectionFactory
to declare all exchanges and queues in the enclosing application context.
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.AbstractJavaTypeMapper
-
- afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- afterPropertiesSet() - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
- AmqpAdmin - Interface in org.springframework.amqp.core
-
Specifies a basic set of portable AMQP administrative operations for AMQP > 0.8
- AmqpAppender - Class in org.springframework.amqp.rabbit.log4j
-
A Log4J appender that publishes logging events to an AMQP Exchange.
- AmqpAppender() - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- AmqpAppender.Event - Class in org.springframework.amqp.rabbit.log4j
-
Small helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
- AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.log4j
-
Helper class to actually send LoggingEvents asynchronously.
- AmqpAuthenticationException - Exception in org.springframework.amqp
-
Runtime wrapper for an authentication exception.
- AmqpAuthenticationException(Throwable) - Constructor for exception org.springframework.amqp.AmqpAuthenticationException
-
- AmqpClientInterceptor - Class in org.springframework.amqp.remoting.client
-
MethodInterceptor
for accessing RMI-style AMQP services.
- AmqpClientInterceptor() - Constructor for class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- AmqpConnectException - Exception in org.springframework.amqp
-
RuntimeException wrapper for an
ConnectException
which can be commonly thrown from AMQP operations if the
remote process dies or there is a network issue.
- AmqpConnectException(Exception) - Constructor for exception org.springframework.amqp.AmqpConnectException
-
- 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
-
- 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
-
- AmqpProxyFactoryBean - Class in org.springframework.amqp.remoting.client
-
FactoryBean
for AMQP proxies.
- AmqpProxyFactoryBean() - Constructor for class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- AmqpRejectAndDontRequeueException - Exception in org.springframework.amqp
-
Exception for listener implementations used to indicate the
basic.reject will be sent with requeue=false in order to enable
features such as DLQ.
- AmqpRejectAndDontRequeueException(String, Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
- AmqpRejectAndDontRequeueException(String) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
- AmqpRejectAndDontRequeueException(Throwable) - Constructor for exception org.springframework.amqp.AmqpRejectAndDontRequeueException
-
- AmqpTemplate - Interface in org.springframework.amqp.core
-
Specifies a basic set of AMQP operations.
- 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
-
- AnonymousQueue() - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
- AnonymousQueue(Map<String, Object>) - Constructor for class org.springframework.amqp.core.AnonymousQueue
-
- append(LoggingEvent) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- APPLICATION_ID - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
Key name for the application id (if there is one set via the appender config) in the message properties.
- applyCommonSettings(AbstractRetryOperationsInterceptorFactoryBean) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
- asyncRpc(Method) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- await(Long, TimeUnit) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- 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, int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a host name
and port.
- CachingConnectionFactory(int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a port on the hostname returned from
InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
- CachingConnectionFactory(String) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory given a host name.
- CachingConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Create a new CachingConnectionFactory for the given target ConnectionFactory.
- CachingConnectionFactory.CacheMode - Enum in org.springframework.amqp.rabbit.connection
-
- CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
Key name for the logger level name in the message properties
- CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
Key name for the logger category name in the message properties
- ChannelAwareMessageListener - Interface in org.springframework.amqp.rabbit.core
-
A message listener that is aware of the Channel on which the message was received.
- ChannelCallback<T> - Interface in org.springframework.amqp.rabbit.core
-
Basic callback for use in RabbitTemplate
- ChannelListener - Interface in org.springframework.amqp.rabbit.connection
-
- ChannelProxy - Interface in org.springframework.amqp.rabbit.connection
-
Subinterface of Channel
to be implemented by
Channel proxies.
- checkMessageListener(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Check the given message listener, throwing an exception if it does not correspond to a supported listener type.
- checkWhiteList(Class<?>) - Method in class org.springframework.amqp.support.converter.WhiteListDeserializingMessageConverter
-
- 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.support.PublisherCallbackChannelImpl
-
- clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- clearConnectionListeners() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- clearDelegates() - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- clearFlowListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- clearReturnListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- close() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Close this connection and all its channels
with the AMQP.REPLY_SUCCESS
close code
and message 'OK'.
- close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- close() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- close(int, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- close() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- closeAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- closeChannel(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Close the given RabbitMQ Channel and ignore any thrown exception.
- closeConnection(Connection) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Close the given RabbitMQ Connection and ignore any thrown exception.
- closeMessageConsumer(Channel, Collection<String>, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- commitAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- commitIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Commit the Channel if not within a JTA transaction.
- commitIfNecessary(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Perform a commit or message acknowledgement, as appropriate.
- CompositeChannelListener - Class in org.springframework.amqp.rabbit.connection
-
- CompositeChannelListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- CompositeConnectionListener - Class in org.springframework.amqp.rabbit.connection
-
- CompositeConnectionListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- ConditionalRejectingErrorHandler - Class in org.springframework.amqp.rabbit.listener
-
ErrorHandler
that conditionally wraps the Exception in an
AmqpRejectAndDontRequeueException
if the configured rejection
strategy determines that the message is fatal and should not be requeued.
- ConditionalRejectingErrorHandler() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
Create a handler with the ConditionalRejectingErrorHandler.DefaultExceptionStrategy
.
- ConditionalRejectingErrorHandler(FatalExceptionStrategy) - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
- confirm(CorrelationData, boolean) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
-
- confirmSelect() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- Connection - Interface in org.springframework.amqp.rabbit.connection
-
- ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
-
An interface based ConnectionFactory for creating Connections
.
- 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() - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
- ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.amqp.rabbit.connection
-
Callback interface for resource creation.
- ConnectionListener - Interface in org.springframework.amqp.rabbit.connection
-
- ConnectionProxy - Interface in org.springframework.amqp.rabbit.connection
-
Subinterface of
Connection
to be implemented by
Connection proxies.
- ConsumerCancelledException - Exception in org.springframework.amqp.rabbit.listener
-
Thrown when the broker cancels the consumer and the message
queue is drained.
- ConsumerCancelledException() - Constructor for exception org.springframework.amqp.rabbit.listener.ConsumerCancelledException
-
- ConsumerChannelRegistry - Class in org.springframework.amqp.rabbit.connection
-
Consumers register their primary channels with this class.
- ConsumerChannelRegistry() - Constructor for class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
-
- consumerCount(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- containsChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- CONTENT_TYPE_BYTES - Static variable in class org.springframework.amqp.core.MessageProperties
-
- 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
-
- 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(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertMessageIfNecessary(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertRabbitAccessException(Exception) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- convertRabbitAccessException(Throwable) - Static method in class org.springframework.amqp.rabbit.support.RabbitExceptionTranslator
-
- convertSendAndReceive(Object) - Method in 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- 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
-
- correlationconvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Deprecated.
- correlationConvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- CorrelationData - Class in org.springframework.amqp.rabbit.support
-
Base class for correlating publisher confirms to sent messages.
- CorrelationData(String) - Constructor for class org.springframework.amqp.rabbit.support.CorrelationData
-
- createBareConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- createBlockingQueueConsumer() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- createChannel(boolean) - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Create a new channel, using an internally allocated channel number.
- createChannel(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Create a new RabbitMQ Session for registration with a RabbitResourceHolder.
- createChannel(boolean) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Create a new RabbitMQ Connection for registration with a RabbitResourceHolder.
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Create a RabbitMQ Connection via this template's ConnectionFactory and its host and port values.
- 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.
- 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.Jackson2JsonMessageConverter
-
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
-
- 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.
- createObjectInputStream(InputStream, String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
Create an ObjectInputStream for the given InputStream and codebase.
- createRabbitTemplate(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Create a RabbitTemplate for the given ConnectionFactory.
- CustomExchange - Class in org.springframework.amqp.core
-
Simple container collecting information to describe a custom exchange.
- CustomExchange(String, String) - Constructor for class org.springframework.amqp.core.CustomExchange
-
- CustomExchange(String, String, boolean, boolean) - Constructor for class org.springframework.amqp.core.CustomExchange
-
- CustomExchange(String, String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.CustomExchange
-
- Declarable - Interface in org.springframework.amqp.core
-
Classes implementing this interface can be auto-declared
with the broker during context initialization by an AmqpAdmin
.
- DeclarationException() - Constructor for exception org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.DeclarationException
-
- DeclarationException(Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.DeclarationException
-
- declareBinding(Binding) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Declare a binding of a queue to an exchange.
- declareBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- declareExchange(Exchange) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Declare an exchange
- declareExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- declareQueue() - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Declare a queue whose name is automatically named.
- declareQueue(Queue) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Declare the given queue
- declareQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Declare the given queue.
- declareQueue() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Declares a server-named exclusive, autodelete, non-durable queue.
- declareTransactional(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Declare to that broker that a channel is going to be used transactionally, and convert exceptions that arise.
- DEFAULT - Static variable in class org.springframework.amqp.core.DirectExchange
-
- DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
- DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
- DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
- DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- DEFAULT_EXCHANGE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- DEFAULT_PORT - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- DEFAULT_PREFETCH_COUNT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The default recovery interval: 5000 ms = 5 seconds.
- DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- DefaultClassMapper - Class in org.springframework.amqp.support.converter
-
Maps to/from JSON using type information in the
MessageProperties
;
the default name of the message property containing the type is '__TypeId__'.
- DefaultClassMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultClassMapper
-
- DefaultJackson2JavaTypeMapper - Class in org.springframework.amqp.support.converter
-
- DefaultJackson2JavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
- DefaultJavaTypeMapper - Class in org.springframework.amqp.support.converter
-
- DefaultJavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultJavaTypeMapper
-
- DefaultMessagePropertiesConverter - Class in org.springframework.amqp.rabbit.support
-
- DefaultMessagePropertiesConverter() - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
-
- deleteExchange(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Delete an exchange.
- deleteExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- deleteQueue(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Delete a queue, without regard for whether it is in use or has messages on it
- deleteQueue(String, boolean, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
-
Delete a queue
- deleteQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- deleteQueue(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- deserialize(byte[]) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
- deserialize(ObjectInputStream) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
- destination - Variable in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
-
- destroy() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- destroy() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Close the underlying shared connection.
- destroy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Determine the current lookup key.
- determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
-
- determineShutdownReason(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- determineTargetConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- DIRECT - Static variable in class org.springframework.amqp.core.ExchangeTypes
-
- DirectExchange - Class in org.springframework.amqp.core
-
Simple container collecting information to describe a direct exchange.
- DirectExchange(String) - Constructor for class org.springframework.amqp.core.DirectExchange
-
- DirectExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.DirectExchange
-
- DirectExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.DirectExchange
-
- DirectExchangeParser - Class in org.springframework.amqp.rabbit.config
-
- DirectExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.DirectExchangeParser
-
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doCleanupAfterCompletion(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doGetTransaction() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doInitialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Register any invokers within this container.
- doInitialize() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Creates the specified number of concurrent consumers, in the form of a Rabbit Channel plus associated
MessageConsumer.
- doInRabbit(Channel) - Method in interface org.springframework.amqp.rabbit.core.ChannelCallback
-
Execute any number of operations against the supplied RabbitMQ
Channel
, possibly returning a result.
- doInvokeListener(ChannelAwareMessageListener, Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Invoke the specified listener as Spring ChannelAwareMessageListener, exposing a new Rabbit Session (potentially
with its own transaction) to the listener if demanded.
- doInvokeListener(MessageListener, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Invoke the specified listener as Spring Rabbit MessageListener.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.QueueParser
-
- doParseBindings(Element, ParserContext, String, Element, AbstractExchangeParser) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
-
- doResume(Object, Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doSend(Channel, String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Send the given message to the specified exchange.
- doSendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Send a message and wait for a reply.
- doSendAndReceiveWithFixed(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- doSendAndReceiveWithTemporary(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- doShutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Close the registered invokers.
- doShutdown() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- doStart() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Start this container, and notify all invoker tasks.
- doStart() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Re-initializes this container's Rabbit message consumers, if not initialized already.
- doStop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
This method is invoked when the container is stopping.
- doStop() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- doSuspend(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- 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.
- getAcknowledgeMode() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getActiveConsumerCount() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- 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
-
- getApplicationContext() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getApplicationId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getArguments() - Method in class org.springframework.amqp.core.AbstractExchange
-
Return the collection of arbitrary arguments to use when declaring an exchange.
- 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
-
- 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
-
- getBeanName() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getBody() - Method in class org.springframework.amqp.core.Message
-
- getCacheMode() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getCause() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
-
- getChannel(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Fetch an appropriate Channel from the given RabbitResourceHolder.
- getChannel(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Fetch an appropriate Channel from the given RabbitResourceHolder.
- getChannel() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getChannel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- getChannelCacheSize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getChannelListener() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
A composite channel listener to be used by subclasses when creating and closing channels.
- getChannelNumber() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getCharset() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- getClassIdFieldName() - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- getClassMapper() - Method in class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
- getCloseReason() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getClusterId() - Method in class org.springframework.amqp.core.MessageProperties
-
- getConnection(RabbitResourceHolder) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
-
Fetch an appropriate Connection from the given RabbitResourceHolder.
- getConnection(RabbitResourceHolder) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Fetch an appropriate Connection from the given RabbitResourceHolder.
- getConnection() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getConnection(Class<? extends Connection>) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- getConnection() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getConnectionCachesize() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- getConnectionFactory() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
- 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.
- getConsumerChannel() - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
-
See registerConsumerChannel.
- getConsumerChannel(ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
-
See registerConsumerChannel.
- getConsumerTag() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- 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.log4j.AmqpAppender
-
- getContentLength() - Method in class org.springframework.amqp.core.MessageProperties
-
- getContentType() - Method in class org.springframework.amqp.core.MessageProperties
-
- getContentType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getCorrelationData() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
-
The correlation data supplied by the client when sending the message
corresponding to this confirmation.
- getCorrelationId() - Method in class org.springframework.amqp.core.MessageProperties
-
- getCount() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- 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.
- getDefaultCharset() - Method in class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
- getDefaultConsumer() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getDefaultHostName() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- getDefaultListenerMethod() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- getDelegate() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- getDelegate() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
-
- getDeliveryTag() - Method in class org.springframework.amqp.core.MessageProperties
-
- getDestination() - Method in class org.springframework.amqp.core.Binding
-
- getDestinationType() - Method in class org.springframework.amqp.core.Binding
-
- getEvent() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
-
- getExchange() - Method in class org.springframework.amqp.core.Binding
-
- getExchangeName() - Method in class org.springframework.amqp.core.Address
-
- getExchangeName() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getExchangeType() - Method in class org.springframework.amqp.core.Address
-
- getExchangeType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getExpiration() - Method in class org.springframework.amqp.core.MessageProperties
-
- getFailedMessage() - Method in exception org.springframework.amqp.rabbit.listener.ListenerExecutionFailedException
-
- getFailedQueues() - Method in exception org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.DeclarationException
-
- 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.log4j.AmqpAppender
-
- getId() - Method in class org.springframework.amqp.rabbit.support.CorrelationData
-
- getIdClassMapping() - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- getJavaTypeMapper() - Method in class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
-
- getJavaTypeMapper() - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
-
- 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
-
- getListenerMethodName(Message, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Determine the name of the listener method that is supposed to handle the given message.
- getMaxSenderRetries() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getMessage() - Method in exception org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.DeclarationException
-
- 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.adapter.MessageListenerAdapter
-
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 class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
-
- getMessageCount() - Method in class org.springframework.amqp.core.MessageProperties
-
- getMessageId() - Method in class org.springframework.amqp.core.MessageProperties
-
- getMessageListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getMessageProperties() - Method in class org.springframework.amqp.core.Message
-
- getMessageRecoverer() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- 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
-
- getNextPublishSeqNo() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- getObject() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- 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.StatefulRetryOperationsInterceptorFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- getObjectType() - Method in class org.springframework.amqp.remoting.client.AmqpProxyFactoryBean
-
- getPassword() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getPhase() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.log4j.AmqpAppender
-
- getPriority() - Method in class org.springframework.amqp.core.MessageProperties
-
- getProperties() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
-
- 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
-
- getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getQueueNamesAsSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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
-
- getRabbitAdmin() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
- getReceivedExchange() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- getReceivedRoutingKey() - Method in class org.springframework.amqp.core.MessageProperties
-
- getRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
-
- getRemoteInvocationFactory() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- getReplyTo() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReplyToAddress() - Method in class org.springframework.amqp.core.MessageProperties
-
- getReplyToAddress(Message, T) - Method in interface org.springframework.amqp.core.ReplyToAddressCallback
-
- getReplyToAddress(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Determine a reply-to Address for the given message.
- getRequiredQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- 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.
- getRetryOperations() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- getRoutingKey() - Method in class org.springframework.amqp.core.Address
-
- getRoutingKey() - Method in class org.springframework.amqp.core.Binding
-
- getRoutingKey() - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
- getRoutingKeyPattern() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getSenderPoolSize() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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
-
- getTimestamp() - Method in class org.springframework.amqp.core.MessageProperties
-
- getTimestamp() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
-
- getTransactionalResourceHolder(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- 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
-
- getUnconfirmed(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Gets unconfirmed correlatiom data older than age and removes them.
- getUserId() - Method in class org.springframework.amqp.core.MessageProperties
-
- getUsername() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getUUID() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- getUUID() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
-
Returns the UUID used to identify this Listener for returns.
- 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.log4j.AmqpAppender
-
- 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
-
- incrementRetries() - Method in class org.springframework.amqp.rabbit.log4j.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.
- initDefaultStrategies() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Initialize the default implementations for the adapter's strategies.
- initGateway() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Subclasses can override this for custom initialization behavior.
- initialize() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Declares all the exchanges, queues and bindings in the enclosing application context, if any.
- initialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Initialize this container.
- initializeConsumers() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- initializeJsonObjectMapper() - Method in class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
-
Subclass and override to customize.
- initializeJsonObjectMapper() - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
-
Subclass and override to customize.
- invoke(MethodInvocation) - Method in class org.springframework.amqp.rabbit.retry.MissingMessageIdAdvice
-
- 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
-
Invoke the specified listener: either as standard MessageListener or (preferably) as SessionAwareMessageListener.
- invokeListener(Channel, Message) - Method in interface org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer.ContainerDelegate
-
- invokeListener(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- invokeListenerMethod(String, Object[]) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- invokeListenerMethod(String, Object[], Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Invoke the specified listener method.
- isActive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isAttributeDefined(Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Checks the attribute to see if it is defined in the given element.
- isAutoAck() - Method in enum org.springframework.amqp.core.AcknowledgeMode
-
- 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.log4j.AmqpAppender
-
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this
template's Channel handling and not by an external transaction coordinator.
- isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this
listener container's Channel handling and not by an external transaction coordinator.
- isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- isChannelTransacted() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- isChannelTransactional(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
Determine whether the given RabbitMQ Channel is transactional, that is, bound to the current thread by Spring's
transaction facilities.
- isChannelTransactional() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- isConfirmListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- isConfirmListener() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
-
- 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.log4j.AmqpAppender
-
- 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.log4j.AmqpAppender
-
- isExclusive() - Method in class org.springframework.amqp.core.Queue
-
True if the server should only send messages to the declarer's connection.
- 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 interface org.springframework.amqp.rabbit.listener.FatalExceptionStrategy
-
- isFrozen() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- isGenerateId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- isManual() - Method in enum org.springframework.amqp.core.AcknowledgeMode
-
- isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
-
Query a message to see if it has been seen before.
- isNormalChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- isNormalShutdown(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- isOpen() - Method in interface org.springframework.amqp.rabbit.connection.Connection
-
Flag to indicate the status of the connection.
- isOpen() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- isOpen() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- isPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Gets and removes a ThreadLocal indicating the channel MUST be physically closed.
- isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- isRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
-
- isReleaseAfterCompletion() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Whether the resources should be released after transaction completion.
- isReturnListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- isReturnListener() - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
-
- isRunning() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Determine whether this container is currently running, that is, whether it has been started and not stopped yet.
- 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
-
- 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.
- isTransactionAllowed() - Method in enum org.springframework.amqp.core.AcknowledgeMode
-
- 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
-
- RabbitExceptionTranslator - Class in org.springframework.amqp.rabbit.support
-
Translates Rabbit Exceptions to the
AmqpException
class
hierarchy.
- RabbitExceptionTranslator() - Constructor for class org.springframework.amqp.rabbit.support.RabbitExceptionTranslator
-
- RabbitGatewaySupport - Class in org.springframework.amqp.rabbit.core.support
-
Convenient super class for application classes that need RabbitMQ access.
- RabbitGatewaySupport() - Constructor for class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
- 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
-
- RabbitNamespaceUtils() - Constructor for class org.springframework.amqp.rabbit.config.RabbitNamespaceUtils
-
- RabbitOperations - Interface in org.springframework.amqp.rabbit.core
-
Rabbit specific methods for Amqp functionality.
- RabbitResourceHolder - Class in org.springframework.amqp.rabbit.connection
-
Rabbit resource holder, wrapping a RabbitMQ Connection and Channel.
- RabbitResourceHolder() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Create a new RabbitResourceHolder that is open for resources to be added.
- RabbitResourceHolder(Channel, boolean) - Constructor for class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- RabbitTemplate - Class in org.springframework.amqp.rabbit.core
-
Helper class that simplifies synchronous RabbitMQ access (sending and receiving messages).
- RabbitTemplate() - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Convenient constructor for use with setter injection.
- RabbitTemplate(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Create a rabbit template with default strategies and settings.
- RabbitTemplate.ConfirmCallback - Interface in org.springframework.amqp.rabbit.core
-
- RabbitTemplate.ReturnCallback - Interface in org.springframework.amqp.rabbit.core
-
- RabbitTransactionManager - Class in org.springframework.amqp.rabbit.transaction
-
- RabbitTransactionManager() - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
Create a new RabbitTransactionManager for bean-style usage.
- RabbitTransactionManager(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
Create a new RabbitTransactionManager, given a ConnectionFactory.
- RabbitUtils - Class in org.springframework.amqp.rabbit.connection
-
- RabbitUtils() - Constructor for class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- receive() - Method in 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() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receive(String) - 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() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receiveAndConvert(String) - 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
-
- recover(Message, Throwable) - Method in interface org.springframework.amqp.rabbit.retry.MessageRecoverer
-
Callback for message that was consumed but failed all retry attempts.
- recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RejectAndDontRequeueRecoverer
-
- recover(Message, Throwable) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- recoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply a Message recoverer - default is to log and discard after retry is exhausted.
- recoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
-
- 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
-
- 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
-
- releaseResources(RabbitResourceHolder) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
-
- 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
-
- removeConfirmListener(ConfirmListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- removeConnectionListener(ConnectionListener) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
-
- removeDelegate(ConnectionListener) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- removeFlowListener(FlowListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- removeHeader(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- removeHeaders() - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- removeListener(PublisherCallbackChannel.Listener) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
-
Gets a reference to the current listener, or null.
- removeListener(PublisherCallbackChannel.Listener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- removePendingConfirmsReference(Channel, SortedMap<Long, PendingConfirm>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- removePendingConfirmsReference(Channel, SortedMap<Long, PendingConfirm>) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
-
When called, this listener must remove all references to the
pending confirm map.
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Remove queue(s) from this container's list of queues.
- removeQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Remove queues from this container's list of queues.
- removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Remove queue(s) from this container's list of queues.
- removeQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Remove queue(s) from this container's list of queues.
- removeReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- removeShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- removeTargetConnectionFactory(Object) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- 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
-
- requiresLayout() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- reset() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Reset the Channel cache and underlying shared Connection, to be reinitialized on next access.
- reset() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- retrieveHeader(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
-
- RetryInterceptorBuilder<T extends org.aopalliance.intercept.MethodInterceptor> - Class in org.springframework.amqp.rabbit.config
-
Simplified facade to make it easier and simpler to build a
StatefulRetryOperationsInterceptor
or
(stateless) RetryOperationsInterceptor
by providing a fluent interface to defining the behavior on error.
- RetryInterceptorBuilder.StatefulRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
-
- RetryInterceptorBuilder.StatelessRetryInterceptorBuilder - Class in org.springframework.amqp.rabbit.config
-
- retryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply the retry operations - once this is set, other properties can no longer be set; can't
be set if other properties have been applied.
- retryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
-
- retryPolicy(RetryPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Apply the retry policy - cannot be used if a custom retry template has been provided, or the max attempts or
back off options or policy have been applied.
- retryPolicy(RetryPolicy) - Method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
-
- RETURN_CORRELATION - Static variable in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel
-
- returnedMessage(Message, int, String, String, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ReturnCallback
-
- rollbackAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- rollbackIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
- rollbackOnExceptionIfNecessary(Throwable) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Perform a rollback, handling rollback exceptions properly.
- rpc(Method) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- run() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.EventSender
-
- 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(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 class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- sendResponse(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Send the given response message to the given destination.
- SerializationUtils - Class in org.springframework.amqp.utils
-
Static utility to help with serialization.
- SerializationUtils() - Constructor for class org.springframework.amqp.utils.SerializationUtils
-
- serialize(Object) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
Serialize the object provided.
- SerializerMessageConverter - Class in org.springframework.amqp.support.converter
-
Implementation of
MessageConverter
that can work with Strings or native objects
of any kind via the
Serializer
and
Deserializer
abstractions in Spring.
- SerializerMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SerializerMessageConverter
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Flag controlling the behaviour of the container with respect to message acknowledgement.
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set addresses for clustering.
- 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
-
- setAdviceChain(Advice[]) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Public setter for the Advice
to apply to listener executions.
- 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.core.RabbitAdmin
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setApplicationId(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setCause(String) - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
-
When the confirmation is nacked, set the cause when available.
- setChannelCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setChannelListeners(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- 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.log4j.AmqpAppender
-
- setClassMapper(ClassMapper) - Method in class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
- 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.
- 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.connection.RabbitAccessor
-
Set the ConnectionFactory to use for obtaining RabbitMQ
Connections
.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Set the Rabbit connection factory to be used by the gateway.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- 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
-
- setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- 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.log4j.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.log4j.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
-
- setCorrelationId(byte[]) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setCorrelationId(byte[]) - Method in class org.springframework.amqp.core.MessageProperties
-
- setCorrelationIdIfAbsent(byte[]) - 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.
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the number of retries after passive queue declaration fails.
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set the number of retries after passive queue declaration fails.
- setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.AbstractJsonMessageConverter
-
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.support.PublisherCallbackChannelImpl
-
- setDefaultHashtableClass(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- setDefaultListenerMethod(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Specify the name of the default listener method to delegate to, for the case where no specific listener method
has been determined.
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Determines the default behavior when a message is rejected, for example because the listener
threw an exception.
- setDefaultTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- setDefaultType(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
- setDelegate(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set a target object to delegate message listening to.
- setDelegates(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
-
- setDelegates(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
-
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
-
- 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
-
- setDurable(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The encoding to use when inter-converting between byte arrays and Strings in message properties.
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
The encoding to use when inter-converting between byte arrays and Strings in message properties.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
- setErrorRoutingKeyPrefix(String) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
- setExchange(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default exchange to use for send operations when none is specified.
- setExchangeName(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setExchangeType(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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.
- 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
-
- setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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
-
- 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.rabbit.core.RabbitAdmin
-
- setImmediatePublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- setJavaTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
-
- setJavaTypeMapper(JavaTypeMapper) - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
-
- setJsonObjectMapper(ObjectMapper) - Method in class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
-
The ObjectMapper
to use instead of using the default.
- setJsonObjectMapper(ObjectMapper) - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
-
The ObjectMapper
to use instead of using the default.
- setLenientFallback(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setMandatoryPublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- setMarshaller(Marshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the Marshaller
to be used by this message converter.
- setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Sets an upper limit to the number of consumers; defaults to 'concurrentConsumers'.
- setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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.adapter.MessageListenerAdapter
-
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.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
-
- setMessageCountIfAbsent(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- 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(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the message listener implementation to register.
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If all of the configured queue(s) are not available on the broker, this setting
determines whether the condition is fatal (default true).
- setNewMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setPassword(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setPhase(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the phase in which this container should be started and stopped.
- setPhysicalCloseRequired(boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Sets a ThreadLocal indicating the channel MUST be physically closed.
- setPort(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setPort(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Tells the broker how many messages to send to each consumer in a single request.
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
- setPriorityIfAbsentOrDefault(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setPublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setPublisherReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- setQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default queue to receive messages from when none is specified explicitly.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name of the queue(s) to receive messages from.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- 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.SimpleMessageListenerContainer
-
- setQuiesce(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Stop receiving new messages; drain the queue of any prefetched messages.
- setRabbitAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set the
RabbitAdmin
, used to declare any auto-delete queues, bindings
etc when the container is started.
- setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Set the RabbitTemplate for the gateway.
- 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
-
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The time (in milliseconds) that a consumer should wait for data.
- setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Specify the interval between recovery attempts, in milliseconds.
- 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.
- setRemoteInvocationFactory(RemoteInvocationFactory) - Method in class org.springframework.amqp.remoting.client.AmqpClientInterceptor
-
Set the RemoteInvocationFactory to use for this accessor.
- setReplyQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
A queue for replies; if not provided, a temporary exclusive, auto-delete queue will
be used for each reply.
- 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
-
- setRequestedHeartBeat(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setResponseExchange(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set the exchange to use when sending response messages.
- setResponseRoutingKey(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set the routing key to use when sending response messages.
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
When consuming multiple queues, set the interval between declaration attempts when only
a subset of the queues were available (milliseconds).
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
When consuming multiple queues, set the interval between declaration attempts when only
a subset of the queues were available (milliseconds).
- setRetryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add a RetryTemplate
which will be used for all rabbit operations.
- setReturnCallback(RabbitTemplate.ReturnCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
-
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The value of a default routing key to use for send operations when none is specified.
- 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.log4j.AmqpAppender
-
- setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setSerializer(Serializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
The serializer to use for converting Java objects to message bodies.
- 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
-
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The time to wait for workers in milliseconds after the container is stopped, and before the connection is forced
closed.
- setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setTargetConnectionFactories(Map<Object, ConnectionFactory>) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify the map of target ConnectionFactories, with the lookup key as key.
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- 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
-
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
- 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
-
- setTypeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setUnmarshaller(Unmarshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the Unmarshaller
to be used by this message converter.
- setUserId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
-
- setUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
- 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.log4j.AmqpAppender
-
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the specified bean definition property with the value of the attribute whose name is provided if that
attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition property corresponding to the specified attributeName with the value of that
attribute if it is defined in the given element.
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.log4j.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
-
- shutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- 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).
- SimpleMessageListenerContainer.ContainerDelegate - Interface in org.springframework.amqp.rabbit.listener
-
- 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
-
- start() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Start this container.
- start() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- startSenders() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
Submit the required number of senders into the pool.
- stateful() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateful retry interceptor.
- StatefulRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateful retry interceptor for use in a message listener container, giving you
a large amount of control over the behaviour of a container when a listener fails.
- StatefulRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
-
- stateless() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateless retry interceptor.
- StatelessRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateless retry interceptor for use in a message listener container, giving
you a large amount of control over the behaviour of a container when a listener fails.
- StatelessRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
-
- stop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Stop this container.
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- stop() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
- SYSTEM - Static variable in class org.springframework.amqp.core.ExchangeTypes
-