- 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.
- AbstractExchangeParser - Class in org.springframework.amqp.rabbit.config
-
- AbstractExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.AbstractExchangeParser
-
- AbstractMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
-
- AbstractMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- AbstractMessageListenerContainer.SharedConnectionNotInitializedException - Exception in org.springframework.amqp.rabbit.listener
-
Exception that indicates that the initial setup of this container's shared Rabbit Connection failed.
- AbstractMessageListenerContainer.SharedConnectionNotInitializedException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.SharedConnectionNotInitializedException
-
Create a new SharedConnectionNotInitializedException.
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- addReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- addShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
- afterPropertiesSet() - Method in class org.springframework.amqp.rabbit.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.
- 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.Event(LoggingEvent, Map) - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
-
- AmqpAppender.EventSender - Class in org.springframework.amqp.rabbit.log4j
-
Helper class to actually send LoggingEvents asynchronously.
- AmqpAppender.EventSender() - Constructor for class org.springframework.amqp.rabbit.log4j.AmqpAppender.EventSender
-
- 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.
- 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
-
- 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
-
- containsChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- 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 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
-
- 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.
- createRabbitTemplate(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Create a RabbitTemplate for the given ConnectionFactory.
- declareBinding(Binding) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- declareExchange(Exchange) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- 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_CLOSE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- DEFAULT_EXCHANGE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- 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
-
- DefaultMessagePropertiesConverter - Class in org.springframework.amqp.rabbit.support
-
- DefaultMessagePropertiesConverter() - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
-
- deleteExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- deleteQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- deleteQueue(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- 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
-
- determineTargetConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
- 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
-
- 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
-
- getApplicationId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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
-
- getBeanFactory() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getBeanName() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getCacheMode() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- 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
-
- getCloseReason() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- 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
-
- getContentEncoding() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getContentType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getCorrelationData() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
-
- getCount() - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
-
- 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
-
- getEvent() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
-
- getExchangeName() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getExchangeType() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- getFailedQueues() - Method in exception org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.DeclarationException
-
- getFlow() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- 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
-
- getKey(Message) - Method in interface org.springframework.amqp.rabbit.retry.MessageKeyGenerator
-
Generate a unique key for the message that is repeatable on redelivery.
- 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.
- getMessageListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getMessageRecoverer() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
-
- 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
-
- 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
-
- 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
-
- getProperties() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
-
- getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getQueueNamesAsSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- getQueueProperties(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
- getReceivedExchange(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
- 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
-
- 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.
- 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
-
- getUnconfirmed(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Gets unconfirmed correlatiom data older than age and removes them.
- 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
-
- 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
-
- invoke(MethodInvocation) - Method in class org.springframework.amqp.rabbit.retry.MissingMessageIdAdvice
-
- 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
-
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.
- 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
-
- isDeclareExchange() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- isDurable() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- isExistingTransaction(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
-
- isExposeListenerChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- isFrozen() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
- isGenerateId() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
-
Query a message to see if it has been seen before.
- 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
-
- 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
-
- 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.
- 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 class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- receive(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
- 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 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
-
- 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 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
-
- 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
-
- 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
-
- 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 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 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.
- 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(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.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- 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.
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
- 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
-
- 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).
- 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.rabbit.log4j.AmqpAppender
-
- setContentType(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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.
- setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setDefaultConsumer(Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
-
- setDefaultListenerMethod(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Specify the name of the default listener method to delegate to, for the case where no specific listener method
has been determined.
- 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
-
- 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
-
- 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.
- setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
- setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
- setHost(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
- setImmediatePublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Deprecated.
'immediate' no longer support by RabbitMQ.
- 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
-
- 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.
- 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
-
- 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.
- 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.
- setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
-
Set the RabbitTemplate for the gateway.
- 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.
- 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.
- 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.
- 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.
- 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.
- setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
-
- 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
-
- 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).
- 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
-
- sharedConnectionEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Always use a shared Rabbit Connection.
- 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
-
- SimpleConnection - Class in org.springframework.amqp.rabbit.connection
-
Simply a Connection.
- SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
-
- 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
-