Spring AMQP
A B C D E F G H I J K L M N O P Q R S T U V W 

A

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
Base class for Declarable classes.
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
Convenient base class for MessageConverter implementations.
AbstractMessageConverter() - Constructor for class org.springframework.amqp.support.converter.AbstractMessageConverter
 
AbstractMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
 
AbstractMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
AbstractMessageListenerContainer.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
 
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
 
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.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
 
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
 
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
 
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
 
afterPropertiesSet() - Method in class org.springframework.erlang.connection.SimpleConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.erlang.support.ErlangAccessor
 
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.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
 
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
 
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 - Class in org.springframework.erlang.core
Describes an Erlang application.
Application(String, String, String) - Constructor for class org.springframework.erlang.core.Application
 
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.
asyncRpc(Method) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
await(Long, TimeUnit) - Method in class org.springframework.amqp.rabbit.listener.ActiveObjectCounter
 

B

Background - Class in org.springframework.util.exec
Class to execute processes in the background.
Background() - Constructor for class org.springframework.util.exec.Background
 
basicAck(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicCancel(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, String, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, Consumer) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicGet(String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicNack(long, boolean, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicPublish(String, String, boolean, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicQos(int, int, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicQos(int) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicRecover() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicRecover(boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicRecoverAsync(boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
basicReject(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
bind(Queue) - Static method in class org.springframework.amqp.core.BindingBuilder
 
bind(Exchange) - Static method in class org.springframework.amqp.core.BindingBuilder
 
Binding - Class in org.springframework.amqp.core
Simple container collecting information to describe a binding.
Binding(String, Binding.DestinationType, String, String, Map<String, Object>) - Constructor for class org.springframework.amqp.core.Binding
 
Binding.DestinationType - Enum in org.springframework.amqp.core
 
BINDING_EXCHANGE_ATTR - Static variable in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
BINDING_QUEUE_ATTR - Static variable in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
BindingBuilder - Class in org.springframework.amqp.core
Basic builder class to create bindings for a more fluent API style in code based configuration.
BindingBuilder() - Constructor for class org.springframework.amqp.core.BindingBuilder
 
BindingBuilder.DestinationConfigurer - Class in org.springframework.amqp.core
 
BindingBuilder.DirectExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
 
BindingBuilder.GenericArgumentsConfigurer - Class in org.springframework.amqp.core
 
BindingBuilder.GenericArgumentsConfigurer(BindingBuilder.GenericExchangeRoutingKeyConfigurer, String) - Constructor for class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
 
BindingBuilder.GenericExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
 
BindingBuilder.HeadersExchangeMapConfigurer - Class in org.springframework.amqp.core
 
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeKeysBindingCreator - Class in org.springframework.amqp.core
 
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeMapBindingCreator - Class in org.springframework.amqp.core
 
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator - Class in org.springframework.amqp.core
 
BindingBuilder.TopicExchangeRoutingKeyConfigurer - Class in org.springframework.amqp.core
 
BindingFactoryBean - Class in org.springframework.amqp.rabbit.config
 
BindingFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.BindingFactoryBean
 
bindResourceToTransaction(RabbitResourceHolder, ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
 
BlockingQueueConsumer - Class in org.springframework.amqp.rabbit.listener
Specialized consumer encapsulating knowledge of the broker connections and having its own lifecycle (start and stop).
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
BlockingQueueConsumer(ConnectionFactory, MessagePropertiesConverter, ActiveObjectCounter<BlockingQueueConsumer>, AcknowledgeMode, boolean, int, boolean, String...) - Constructor for class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Create a consumer.
buildListenerArguments(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Build an array of arguments to be passed into the target listener method.
buildMessage(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Build a Rabbit message to be sent as response based on the given result object.

C

CachingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
A ConnectionFactory implementation that returns the same Connections from all CachingConnectionFactory.createConnection() calls, and ignores calls to Connection.close() and caches Channel.
CachingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
Create a new CachingConnectionFactory initializing the hostname to be the value returned from InetAddress.getLocalHost(), or "localhost" if getLocalHost() throws an exception.
CachingConnectionFactory(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.
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.
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.
cleanUp() - Method in class org.springframework.util.exec.ExecuteWatchdog
reset the monitor flag and the process.
clearConfirmListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
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
 
close() - Method in interface org.springframework.erlang.connection.Connection
Close the connection to the remote node.
close() - Method in class org.springframework.erlang.connection.DefaultConnection
 
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.
closeConnection(Connection) - Method in class org.springframework.erlang.connection.SingleConnectionFactory
Close the given Connection.
closeMessageConsumer(Channel, 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
 
Connection - Interface in org.springframework.erlang.connection
A simple interface that is used to wrap access to the OtpConnection class in order to support caching of OptConnections via method interception.
ConnectionCallback<T> - Interface in org.springframework.erlang.core
Basic callback for use in ErlangTemplate
ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
An interface based ConnectionFactory for creating Connections.
ConnectionFactory - Interface in org.springframework.erlang.connection
An interface based ConnectionFactory for creating OtpConnections.
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 - Class in org.springframework.erlang.connection
 
ConnectionFactoryUtils() - Constructor for class org.springframework.erlang.connection.ConnectionFactoryUtils
 
ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.amqp.rabbit.connection
Callback interface for resource creation.
ConnectionListener - Interface in org.springframework.amqp.rabbit.connection
 
ConnectionParameters - Class in org.springframework.erlang.connection
Encapsulate properties to create a OtpConnection
ConnectionParameters(OtpSelf, OtpPeer) - Constructor for class org.springframework.erlang.connection.ConnectionParameters
 
ConnectionProxy - Interface in org.springframework.amqp.rabbit.connection
Subinterface of Connection to be implemented by Connection proxies.
ConnectionProxy - Interface in org.springframework.erlang.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
 
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_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
 
convertBasicTypeToErlang(Object) - Method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
convertErlangToBasicType(OtpErlangObject) - Method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
convertMessageIfNecessary(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
convertOtpAccessException(Exception) - Method in class org.springframework.erlang.core.ErlangTemplate
Convert the specified checked exception to a Spring runtime exception equivalent.
convertOtpAccessException(Exception) - Method in class org.springframework.erlang.support.ErlangAccessor
 
convertOtpAccessException(Exception) - Static method in class org.springframework.erlang.support.ErlangUtils
 
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
 
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.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.
createConnection() - Method in interface org.springframework.erlang.connection.ConnectionFactory
 
createConnection() - Method in class org.springframework.erlang.connection.SimpleConnectionFactory
 
createConnection() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
createConnection() - Method in class org.springframework.erlang.support.ErlangAccessor
 
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.
createProcessErrorPump(InputStream, OutputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
 
createProcessOutputPump(InputStream, OutputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
 
createPump(InputStream, OutputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
Creates a stream pumper to copy the given input stream to the given output stream.
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
 

D

Declarable - Interface in org.springframework.amqp.core
Classes implementing this interface can be auto-declared with the broker during context initialization by an AmqpAdmin.
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
 
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 - Static variable in class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
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
 
DefaultConnection - Class in org.springframework.erlang.connection
Basic implementation of ConnectionProxy that delegates to an underlying OtpConnection.
DefaultConnection(OtpConnection) - Constructor for class org.springframework.erlang.connection.DefaultConnection
 
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
Default implementation of the MessagePropertiesConverter strategy.
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
Calls AbstractMessageListenerContainer.shutdown() when the BeanFactory destroys the container instance.
destroy() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
Close the underlying shared connection.
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
 
doCreateConnection() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
Create a JInterface Connection via this class's ConnectionFactory.
doGetTransaction() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
doInConnection(Connection) - Method in interface org.springframework.erlang.core.ConnectionCallback
Execute any number of operations against the supplied OTP connection, possibly returning a result.
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.FederatedExchangeParser
 
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
 

E

equals(Object) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
ErlangAccessor - Class in org.springframework.erlang.support
 
ErlangAccessor() - Constructor for class org.springframework.erlang.support.ErlangAccessor
 
ErlangBadRpcException - Exception in org.springframework.erlang
Exception thrown when an 'badrpc' is received from an Erlang RPC call.
ErlangBadRpcException(String) - Constructor for exception org.springframework.erlang.ErlangBadRpcException
 
ErlangBadRpcException(OtpErlangTuple) - Constructor for exception org.springframework.erlang.ErlangBadRpcException
 
ErlangConversionException - Exception in org.springframework.erlang.support.converter
 
ErlangConversionException(String, Throwable) - Constructor for exception org.springframework.erlang.support.converter.ErlangConversionException
 
ErlangConversionException(String) - Constructor for exception org.springframework.erlang.support.converter.ErlangConversionException
 
ErlangConverter - Interface in org.springframework.erlang.support.converter
Converter between Java and Erlang Types.
ErlangErrorRpcException - Exception in org.springframework.erlang
Exception thrown when an 'error' is received from an Erlang RPC call
ErlangErrorRpcException(String) - Constructor for exception org.springframework.erlang.ErlangErrorRpcException
 
ErlangErrorRpcException(OtpErlangTuple) - Constructor for exception org.springframework.erlang.ErlangErrorRpcException
 
ErlangOperations - Interface in org.springframework.erlang.core
Operations to perform against OTP/Erlang
ErlangTemplate - Class in org.springframework.erlang.core
 
ErlangTemplate(ConnectionFactory) - Constructor for class org.springframework.erlang.core.ErlangTemplate
 
ErlangUtils - Class in org.springframework.erlang.support
 
ErlangUtils() - Constructor for class org.springframework.erlang.support.ErlangUtils
 
Escape - Class in org.springframework.util.exec
 
Escape() - Constructor for class org.springframework.util.exec.Escape
 
escape(String) - Static method in class org.springframework.util.exec.Escape
Escape a string by quoting the magical elements (such as whitespace, quotes, slashes, etc.)
exchange - Variable in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
Exchange - Interface in org.springframework.amqp.core
 
exchangeBind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclare(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDelete(String, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeDelete(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
ExchangeTypes - Class in org.springframework.amqp.core
Constants for the standard Exchange type names.
ExchangeTypes() - Constructor for class org.springframework.amqp.core.ExchangeTypes
 
exchangeUnbind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exchangeUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
exec(String[]) - Static method in class org.springframework.util.exec.Background
Execute the command (and its args, ala Runtime.exec), sending the output && error streams to the void.
exec(String[], File, boolean, File, boolean) - Static method in class org.springframework.util.exec.Background
Execute a command (and its args, ala Runtime.exec)
execute(ChannelCallback<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
 
execute(ChannelCallback<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
execute(ConnectionCallback<T>) - Method in interface org.springframework.erlang.core.ErlangOperations
 
execute(ConnectionCallback<T>) - Method in class org.springframework.erlang.core.ErlangTemplate
 
Execute - Class in org.springframework.util.exec
Runs an external program.
Execute() - Constructor for class org.springframework.util.exec.Execute
Creates a new execute object using PumpStreamHandler for stream handling.
Execute(ExecuteStreamHandler) - Constructor for class org.springframework.util.exec.Execute
Creates a new execute object.
Execute(ExecuteStreamHandler, ExecuteWatchdog) - Constructor for class org.springframework.util.exec.Execute
Creates a new execute object.
execute() - Method in class org.springframework.util.exec.Execute
Runs a process defined by the command line and returns its exit status.
execute(Vector<String>, String, File) - Static method in class org.springframework.util.exec.Execute
 
execute(Vector<String>, Vector<String>, File) - Static method in class org.springframework.util.exec.Execute
 
execute(Vector<String>, Vector<String>, File, int) - Static method in class org.springframework.util.exec.Execute
Wrapper for common execution patterns
executeAndConvertRpc(String, String, ErlangConverter, Object...) - Method in interface org.springframework.erlang.core.ErlangOperations
 
executeAndConvertRpc(String, String, Object...) - Method in interface org.springframework.erlang.core.ErlangOperations
 
executeAndConvertRpc(String, String, ErlangConverter, Object...) - Method in class org.springframework.erlang.core.ErlangTemplate
 
executeAndConvertRpc(String, String, Object...) - Method in class org.springframework.erlang.core.ErlangTemplate
 
executeErlangRpc(String, String, OtpErlangList) - Method in interface org.springframework.erlang.core.ErlangOperations
 
executeErlangRpc(String, String, OtpErlangObject...) - Method in interface org.springframework.erlang.core.ErlangOperations
 
executeErlangRpc(String, String, OtpErlangList) - Method in class org.springframework.erlang.core.ErlangTemplate
 
executeErlangRpc(String, String, OtpErlangObject...) - Method in class org.springframework.erlang.core.ErlangTemplate
 
executeListener(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Execute the specified listener, committing or rolling back the transaction afterwards (if necessary).
executeRpc(String, String, Object...) - Method in interface org.springframework.erlang.core.ErlangOperations
 
executeRpc(String, String, Object...) - Method in class org.springframework.erlang.core.ErlangTemplate
 
ExecuteStreamHandler - Interface in org.springframework.util.exec
Used by Execute to handle input and output stream of subprocesses.
ExecuteWatchdog - Class in org.springframework.util.exec
Destroys a process running for too long.
ExecuteWatchdog(int) - Constructor for class org.springframework.util.exec.ExecuteWatchdog
Creates a new watchdog with a given timeout.
exist() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeKeysBindingCreator
 
exists() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator
 
extractBoolean(OtpErlangObject) - Static method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
extractLong(OtpErlangObject) - Static method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
extractMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Extract the message body from the given Rabbit message.
extractPid(OtpErlangObject) - Static method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 

F

FANOUT - Static variable in class org.springframework.amqp.core.ExchangeTypes
 
FanoutExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a fanout exchange.
FanoutExchange(String) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.FanoutExchange
 
FanoutExchangeParser - Class in org.springframework.amqp.rabbit.config
 
FanoutExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
FatalListenerExecutionException - Exception in org.springframework.amqp.rabbit.listener
Exception to be thrown when the execution of a listener method failed unrecoverably.
FatalListenerExecutionException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.FatalListenerExecutionException
Constructor for ListenerExecutionFailedException.
FatalListenerExecutionException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.FatalListenerExecutionException
Constructor for ListenerExecutionFailedException.
FatalListenerStartupException - Exception in org.springframework.amqp.rabbit.listener
Exception to be thrown when the execution of a listener method failed on startup.
FatalListenerStartupException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.FatalListenerStartupException
Constructor for ListenerExecutionFailedException.
FEDERATED - Static variable in class org.springframework.amqp.core.ExchangeTypes
Deprecated. 
FederatedExchange - Class in org.springframework.amqp.core
Deprecated.
Starting with version 3.0 RabbitMQ no longer supports 'x-federation' exchanges.
FederatedExchange(String) - Constructor for class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
FederatedExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
FederatedExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
FederatedExchangeParser - Class in org.springframework.amqp.rabbit.config
 
FederatedExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.FederatedExchangeParser
 
flow(boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
fromClass(Class<?>, MessageProperties) - Method in interface org.springframework.amqp.support.converter.ClassMapper
 
fromClass(Class<?>, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
 
fromClass(Class<?>, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
fromClass(Class<?>, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJavaTypeMapper
 
fromErlang(OtpErlangObject) - Method in interface org.springframework.erlang.support.converter.ErlangConverter
Convert from a Erlang data type to a Java object.
fromErlang(OtpErlangObject) - Method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
fromErlangRpc(String, String, OtpErlangObject) - Method in interface org.springframework.erlang.support.converter.ErlangConverter
 
fromErlangRpc(String, String, OtpErlangObject) - Method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
fromInt(int) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
 
fromJavaType(JavaType, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
fromJavaType(JavaType, MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJavaTypeMapper
 
fromJavaType(JavaType, MessageProperties) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
 
fromJavaType(JavaType, MessageProperties) - Method in interface org.springframework.amqp.support.converter.JavaTypeMapper
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.JsonMessageConverter
 
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Unmarshals the given Message into an object.
fromMessage(Message) - Method in interface org.springframework.amqp.support.converter.MessageConverter
Convert from a Message to a Java object.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
Converts from a AMQP Message to an Object.
fromMessage(Message) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Converts from a AMQP Message to an Object.
fromMessageProperties(MessageProperties, String) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
 
fromMessageProperties(MessageProperties, String) - Method in interface org.springframework.amqp.rabbit.support.MessagePropertiesConverter
 

G

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
 
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.FederatedExchangeParser
 
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
Return the bean name that this listener container has been assigned in its containing bean factory, if any.
getBody() - Method in class org.springframework.amqp.core.Message
 
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
 
getCommandline() - Method in class org.springframework.util.exec.Execute
Returns the commandline used to create a subprocess.
getCommandLineString() - Method in class org.springframework.util.exec.Execute
 
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
 
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Return the ConnectionFactory that this accessor uses for obtaining RabbitMQ Connections.
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
Return the Rabbit ConnectionFactory used by the gateway.
getConnectionFactory() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
 
getConnectionFactory() - Method in class org.springframework.erlang.support.ErlangAccessor
 
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
 
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 AmqpAdmins 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
Return the name of the default listener method to delegate to.
getDelegate() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Return the target object to delegate message listening to.
getDeliveryMode() - Method in class org.springframework.amqp.core.MessageProperties
 
getDeliveryTag() - Method in class org.springframework.amqp.core.MessageProperties
 
getDescription() - Method in class org.springframework.erlang.core.Application
 
getDestination() - Method in class org.springframework.amqp.core.Binding
 
getDestinationType() - Method in class org.springframework.amqp.core.Binding
 
getEnvironment() - Method in class org.springframework.util.exec.Execute
Returns the environment used to create a subprocess.
getErlangConverter() - Method in class org.springframework.erlang.core.ErlangTemplate
 
getErr() - Method in class org.springframework.util.exec.PumpStreamHandler
 
getEvent() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender.Event
 
getException() - Method in class org.springframework.util.exec.ExecuteWatchdog
 
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
 
getExitValue() - Method in class org.springframework.util.exec.Execute
query the exit value of the process.
getExpiration() - Method in class org.springframework.amqp.core.MessageProperties
 
getFlow() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
getHeaders() - Method in class org.springframework.amqp.core.MessageProperties
 
getHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
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
 
getId() - Method in class org.springframework.erlang.core.Application
 
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
 
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
Return the message listener object to register.
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
 
getName() - Method in class org.springframework.erlang.core.Node
 
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
 
getOtpPeer() - Method in class org.springframework.erlang.connection.ConnectionParameters
 
getOtpSelf() - Method in class org.springframework.erlang.connection.ConnectionParameters
 
getOut() - Method in class org.springframework.util.exec.PumpStreamHandler
 
getPassword() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
 
getPhase() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the phase in which this container will be started and stopped.
getPort() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
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
 
getProcEnvironment() - Static method in class org.springframework.util.exec.Execute
Find the list of environment variables for this process.
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 DirectFieldAccessors to obtain a property using dotted notation to traverse fields; e.g.
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.amqp.utils.test.TestUtils
 
getQueueNames() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return the name of the queue to receive messages from.
getQueueProperties(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
Returns an implementation-specific Map of properties if the queue exists.
getQueueProperties(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
Returns 3 properties RabbitAdmin.QUEUE_NAME, RabbitAdmin.QUEUE_MESSAGE_COUNT, RabbitAdmin.QUEUE_CONSUMER_COUNT, or null if the queue doesn't exist.
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
getRabbitTemplate() - Method in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
Return the RabbitTemplate for the gateway.
getReasonTuple() - Method in exception org.springframework.erlang.ErlangBadRpcException
 
getReasonTuple() - Method in exception org.springframework.erlang.ErlangErrorRpcException
 
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
 
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) - 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
 
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
 
getSharedConnectionProxy(Connection) - Method in class org.springframework.erlang.connection.SingleConnectionFactory
Wrap the given OtpConnection with a proxy that delegates every method call to it but suppresses close calls.
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.
getTargetConnection() - Method in interface org.springframework.erlang.connection.ConnectionProxy
 
getTargetConnection() - Method in class org.springframework.erlang.connection.DefaultConnection
 
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.FederatedExchange
Deprecated.
 
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.
getVersion() - Method in class org.springframework.erlang.core.Application
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
getVirtualHost() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
 
getVirtualHost() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
 

H

handleAck(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
handleConfirm(PendingConfirm, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleConfirm(PendingConfirm, boolean) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
Invoked by the channel when a confirm is received.
handleListenerException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Handle the given exception that arose during listener execution.
handleListenerException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Handle the given exception that arose during listener execution.
handleNack(long, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
handleResponseError(String, String, OtpErlangObject) - Method in class org.springframework.erlang.core.ErlangTemplate
 
handleResult(Object, Message, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Handle the given result object returned from the listener method, sending a response message back.
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in interface org.springframework.amqp.rabbit.support.PublisherCallbackChannel.Listener
 
handleReturn(int, String, String, String, AMQP.BasicProperties, byte[]) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
handleStartupFailure(Throwable) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Wait for a period determined by the recoveryInterval to give the container a chance to recover from consumer startup failure, e.g.
hashCode() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
HEADERS - Static variable in class org.springframework.amqp.core.ExchangeTypes
 
HeadersExchange - Class in org.springframework.amqp.core
 
HeadersExchange(String) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.HeadersExchange
 
HeadersExchangeParser - Class in org.springframework.amqp.rabbit.config
 
HeadersExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 

I

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
 
initConnection() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
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.
INVALID - Static variable in class org.springframework.util.exec.Execute
Invalid exit code.
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
Invoke the specified listener method.
isActive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Return whether this container is currently active, that is, whether it has been set up but not shut down yet.
isArch(String) - Static method in class org.springframework.util.exec.Os
Determines if the OS on which Ant is executing matches the given OS architecture.
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
 
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
 
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
Return whether to expose the listener Channel to a registered ChannelAwareMessageListener.
isFamily(String) - Static method in class org.springframework.util.exec.Os
Determines if the OS on which Ant is executing matches the given OS family.
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
 
isName(String) - Static method in class org.springframework.util.exec.Os
Determines if the OS on which Ant is executing matches the given OS name.
isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
Query a message to see if it has been seen before.
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
 
isOs(String, String, String, String) - Static method in class org.springframework.util.exec.Os
Determines if the OS on which Ant is executing matches the given OS family, name, architecture and version
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
 
isUniqueSelfNodeName() - Method in class org.springframework.erlang.connection.SimpleConnectionFactory
 
isUniqueSelfNodeName() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
isVersion(String) - Static method in class org.springframework.util.exec.Os
Determines if the OS on which Ant is executing matches the given OS version.
isWatching() - Method in class org.springframework.util.exec.ExecuteWatchdog
Indicates whether or not the watchdog is still monitoring the process.

J

Jackson2JavaTypeMapper - Interface in org.springframework.amqp.support.converter
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
Jackson2JsonMessageConverter - Class in org.springframework.amqp.support.converter
JSON converter that uses the Jackson 2 Json library.
Jackson2JsonMessageConverter() - Constructor for class org.springframework.amqp.support.converter.Jackson2JsonMessageConverter
 
JavaTypeMapper - 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.
JsonMessageConverter - Class in org.springframework.amqp.support.converter
JSON converter that uses the Jackson Json library.
JsonMessageConverter() - Constructor for class org.springframework.amqp.support.converter.JsonMessageConverter
 

K

kill() - Method in class org.springframework.util.exec.Execute
 
killedProcess() - Method in class org.springframework.util.exec.ExecuteWatchdog
Indicates whether the last process run was killed on timeout or not.

L

ListenerExecutionFailedException - Exception in org.springframework.amqp.rabbit.listener
Exception to be thrown when the execution of a listener method failed.
ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.amqp.rabbit.listener.ListenerExecutionFailedException
Constructor for ListenerExecutionFailedException.
logger - Variable in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
 
logger - Variable in class org.springframework.amqp.rabbit.connection.RabbitAccessor
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.core.support.RabbitGatewaySupport
Logger available to subclasses
logger - Variable in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Logger available to subclasses
logger - Variable in class org.springframework.erlang.connection.SimpleConnectionFactory
 
logger - Variable in class org.springframework.erlang.connection.SingleConnectionFactory
 
logger - Variable in class org.springframework.erlang.support.ErlangAccessor
Logger available to subclasses

M

main(String[]) - Static method in class org.springframework.util.exec.Background
 
main(String[]) - Static method in class org.springframework.util.exec.Escape
 
MarshallingMessageConverter - Class in org.springframework.amqp.support.converter
Spring Rabbit MessageConverter that uses a Marshaller and Unmarshaller.
MarshallingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with no Marshaller or Unmarshaller set.
MarshallingMessageConverter(Marshaller) - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller set.
MarshallingMessageConverter(Marshaller, Unmarshaller) - Constructor for class org.springframework.amqp.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller and Unmarshaller.
match() - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeMapBindingCreator
 
matches(Object) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator
 
maybeDeclareExchange() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Maybe declare the exchange.
Message - Class in org.springframework.amqp.core
The 0-8 and 0-9-1 AMQP specifications do not define an Message class or interface.
Message(byte[], MessageProperties) - Constructor for class org.springframework.amqp.core.Message
 
MessageConversionException - Exception in org.springframework.amqp.support.converter
Exception to be thrown by message converters if they encounter a problem with converting a message or object.
MessageConversionException(String, Throwable) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
MessageConversionException(String) - Constructor for exception org.springframework.amqp.support.converter.MessageConversionException
 
MessageConverter - Interface in org.springframework.amqp.support.converter
 
MessageDeliveryMode - Enum in org.springframework.amqp.core
Enumeration for the message delivery mode.
MessageKeyGenerator - Interface in org.springframework.amqp.rabbit.retry
 
MessageListener - Interface in org.springframework.amqp.core
Listener interface to receive asynchronous delivery of Amqp Messages.
MessageListenerAdapter - Class in org.springframework.amqp.rabbit.listener.adapter
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with flexible message type conversion.
MessageListenerAdapter() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter with default settings.
MessageListenerAdapter(Object) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
MessageListenerAdapter(Object, MessageConverter) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
MessageListenerAdapter(Object, String) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate while also declaring its POJO method.
MessagePostProcessor - Interface in org.springframework.amqp.core
To be used with the send method of Amqp template classes (such as RabbitTemplate) that convert an object to a message.
MessageProperties - Class in org.springframework.amqp.core
Message Properties for an AMQP message.
MessageProperties() - Constructor for class org.springframework.amqp.core.MessageProperties
 
MessagePropertiesConverter - Interface in org.springframework.amqp.rabbit.support
Strategy interface for converting between Spring AMQP MessageProperties and RabbitMQ BasicProperties.
MessageRecoverer - Interface in org.springframework.amqp.rabbit.retry
 
MessageRejectedWhileStoppingException - Exception in org.springframework.amqp.rabbit.listener
Exception class that indicates a rejected message on shutdown.
MessageRejectedWhileStoppingException() - Constructor for exception org.springframework.amqp.rabbit.listener.MessageRejectedWhileStoppingException
 
MissingMessageIdAdvice - Class in org.springframework.amqp.rabbit.retry
Advice that can be placed in the listener delegate's advice chain to enhance the message with an ID if not present.
MissingMessageIdAdvice(RetryContextCache) - Constructor for class org.springframework.amqp.rabbit.retry.MissingMessageIdAdvice
 

N

name - Variable in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
NamespaceUtils - Class in org.springframework.amqp.rabbit.config
Shared utility methods for namespace parsers.
NamespaceUtils() - Constructor for class org.springframework.amqp.rabbit.config.NamespaceUtils
 
NewMessageIdentifier - Interface in org.springframework.amqp.rabbit.retry
An optimization for stateful retry of message processing.
nextMessage() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Main application-side API: wait for the next message delivery and return it.
nextMessage(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
Main application-side API: wait for the next message delivery and return it.
noargs() - Method in class org.springframework.amqp.core.BindingBuilder.GenericArgumentsConfigurer
 
Node - Class in org.springframework.erlang.core
Simple description class for an Erlang node.
Node(String) - Constructor for class org.springframework.erlang.core.Node
 
notifyListeners() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 

O

onClose(Connection) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onClose(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
 
onCreate(Channel, boolean) - Method in interface org.springframework.amqp.rabbit.connection.ChannelListener
 
onCreate(Channel, boolean) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
 
onCreate(Connection) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
 
onCreate(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionListener
 
onMessage(Message) - Method in interface org.springframework.amqp.core.MessageListener
 
onMessage(Message, Channel) - Method in interface org.springframework.amqp.rabbit.core.ChannelAwareMessageListener
Callback for processing a received Rabbit message.
onMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
 
onMessage(Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Rabbit MessageListener entry point.
onMessage(Message, Channel) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Spring ChannelAwareMessageListener entry point.
onMessage(Message) - Method in class org.springframework.amqp.remoting.service.AmqpInvokerServiceExporter
 
org.springframework.amqp - package org.springframework.amqp
Base package for Spring AMQP.
org.springframework.amqp.core - package org.springframework.amqp.core
Provides core classes for the spring AMQP abstraction.
org.springframework.amqp.rabbit.config - package org.springframework.amqp.rabbit.config
Provides classes supporting the Rabbit XML namespace.
org.springframework.amqp.rabbit.connection - package org.springframework.amqp.rabbit.connection
Provides classes related to connections.
org.springframework.amqp.rabbit.core - package org.springframework.amqp.rabbit.core
Provides core classes for Spring Rabbit.
org.springframework.amqp.rabbit.core.support - package org.springframework.amqp.rabbit.core.support
Provides core support classes for Spring Rabbit.
org.springframework.amqp.rabbit.listener - package org.springframework.amqp.rabbit.listener
Provides classes for message listener containers.
org.springframework.amqp.rabbit.listener.adapter - package org.springframework.amqp.rabbit.listener.adapter
Provides classes for adapting listeners.
org.springframework.amqp.rabbit.log4j - package org.springframework.amqp.rabbit.log4j
Provides classes supporting Log4J appenders.
org.springframework.amqp.rabbit.retry - package org.springframework.amqp.rabbit.retry
Provides classes supporting retries.
org.springframework.amqp.rabbit.support - package org.springframework.amqp.rabbit.support
Provides support classes for Spring Rabbit.
org.springframework.amqp.rabbit.transaction - package org.springframework.amqp.rabbit.transaction
Provides classes supporting transactions in Spring Rabbit.
org.springframework.amqp.remoting.client - package org.springframework.amqp.remoting.client
Provides classes for the client side of Spring Remoting over AMQP.
org.springframework.amqp.remoting.service - package org.springframework.amqp.remoting.service
Provides classes for the service side of Spring Remoting over AMQP.
org.springframework.amqp.support.converter - package org.springframework.amqp.support.converter
Provides classes for supporting message conversion.
org.springframework.amqp.utils - package org.springframework.amqp.utils
Provides utility classes to support Spring AMQP.
org.springframework.amqp.utils.test - package org.springframework.amqp.utils.test
 
org.springframework.erlang - package org.springframework.erlang
Base package for Spring Erlang.
org.springframework.erlang.connection - package org.springframework.erlang.connection
Provides classes supporting connections.
org.springframework.erlang.core - package org.springframework.erlang.core
Provides core classes for Spring Erlang.
org.springframework.erlang.support - package org.springframework.erlang.support
Provides support classes for Spring Erlang.
org.springframework.erlang.support.converter - package org.springframework.erlang.support.converter
Provides classes conversion between Java and Erlang types.
org.springframework.util.exec - package org.springframework.util.exec
Provides classes supporting execution.
ORIGINAL_DEFAULT_LISTENER_METHOD - Static variable in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Out-of-the-box value for the default listener method: "handleMessage".
Os - Class in org.springframework.util.exec
Condition that tests the OS type.
Os() - Constructor for class org.springframework.util.exec.Os
 
OtpAuthException - Exception in org.springframework.erlang
Runtime exception mirroring the OTP OtpAuthException.
OtpAuthException(OtpAuthException) - Constructor for exception org.springframework.erlang.OtpAuthException
 
OtpAuthException(String, OtpAuthException) - Constructor for exception org.springframework.erlang.OtpAuthException
 
OtpException - Exception in org.springframework.erlang
Base RuntimeException for errors that occur when executing OTP operations.
OtpException(String) - Constructor for exception org.springframework.erlang.OtpException
 
OtpException(Throwable) - Constructor for exception org.springframework.erlang.OtpException
 
OtpException(String, Throwable) - Constructor for exception org.springframework.erlang.OtpException
 
OtpIOException - Exception in org.springframework.erlang
RuntimeException wrapper for an IOException which can be commonly thrown from OTP operations.
OtpIOException(IOException) - Constructor for exception org.springframework.erlang.OtpIOException
 
OtpIOException(String, IOException) - Constructor for exception org.springframework.erlang.OtpIOException
 

P

parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.DirectExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.FanoutExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.FederatedExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.HeadersExchangeParser
 
parseBinding(String, Element, ParserContext) - Method in class org.springframework.amqp.rabbit.config.TopicExchangeParser
 
parseBindings(Element, ParserContext, BeanDefinitionBuilder, String) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseBindings(Element, ParserContext, BeanDefinitionBuilder, String) - Method in class org.springframework.amqp.rabbit.config.FederatedExchangeParser
 
parseContainer(Element, ParserContext) - Static method in class org.springframework.amqp.rabbit.config.RabbitNamespaceUtils
 
parseDeclarationControls(Element, BeanDefinitionBuilder) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
Parses 'auto-declare' and 'declared-by' attributes.
parseDestination(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
 
parseInnerBeanDefinition(Element, ParserContext) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
 
PendingConfirm - Class in org.springframework.amqp.rabbit.support
Instances of this object track pending publisher confirms.
PendingConfirm(CorrelationData, long) - Constructor for class org.springframework.amqp.rabbit.support.PendingConfirm
 
postProcessChannel(Channel, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Post-process the given message producer before using it to send the response.
postProcessMessage(Message) - Method in interface org.springframework.amqp.core.MessagePostProcessor
 
postProcessResponse(Message, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
Post-process the given response message before it will be sent.
prepareConnection(Connection) - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
PublisherCallbackChannel - Interface in org.springframework.amqp.rabbit.support
Instances of this interface support a single listener being registered for publisher confirms with multiple channels, by adding context to the callbacks.
PublisherCallbackChannel.Listener - Interface in org.springframework.amqp.rabbit.support
Listeners implementing this interface can participate in publisher confirms received from multiple channels, by invoking addListener on each channel.
PublisherCallbackChannelImpl - Class in org.springframework.amqp.rabbit.support
Channel wrapper to allow a single listener able to handle confirms from multiple channels.
PublisherCallbackChannelImpl(Channel) - Constructor for class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
PumpStreamHandler - Class in org.springframework.util.exec
Copies standard output and error of subprocesses to standard output and error of the parent process.
PumpStreamHandler(OutputStream, OutputStream) - Constructor for class org.springframework.util.exec.PumpStreamHandler
 
PumpStreamHandler(OutputStream) - Constructor for class org.springframework.util.exec.PumpStreamHandler
 
PumpStreamHandler() - Constructor for class org.springframework.util.exec.PumpStreamHandler
 
purgeQueue(String, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
Purges the contents of the given queue.
purgeQueue(String, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
 

Q

Queue - Class in org.springframework.amqp.core
Simple container collecting information to describe a queue.
Queue(String) - Constructor for class org.springframework.amqp.core.Queue
The queue is durable, non-exclusive and non auto-delete.
Queue(String, boolean) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name and durability flag.
Queue(String, boolean, boolean, boolean) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name, durability, exclusive and auto-delete flags.
Queue(String, boolean, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.Queue
Construct a new queue, given a name, durability flag, and auto-delete flag, and arguments.
QUEUE_CONSUMER_COUNT - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
QUEUE_MESSAGE_COUNT - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
QUEUE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
 
queueBind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueBind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclare() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclare(String, boolean, boolean, boolean, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDeclarePassive(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDelete(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueDelete(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
QueueParser - Class in org.springframework.amqp.rabbit.config
 
QueueParser() - Constructor for class org.springframework.amqp.rabbit.config.QueueParser
 
queuePurge(String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueUnbind(String, String, String) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
queueUnbind(String, String, String, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 

R

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
PlatformTransactionManager implementation for a single Rabbit ConnectionFactory.
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
 
receiveRPC() - Method in interface org.springframework.erlang.connection.Connection
Receive an RPC reply from the remote Erlang node.
receiveRPC() - Method in class org.springframework.erlang.connection.DefaultConnection
 
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
 
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
 
releaseConnection(Connection, ConnectionFactory) - Static method in class org.springframework.erlang.connection.ConnectionFactoryUtils
Release the given Connection by closing it.
releaseConnection(OtpConnection) - Static method in class org.springframework.erlang.support.ErlangUtils
Close the given Connection.
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
 
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.
removeReturnListener(ReturnListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
removeShutdownListener(ShutdownListener) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
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
 
resetConnection() - Method in class org.springframework.erlang.connection.SingleConnectionFactory
Reset the underlying shared Connection, to be reinitialized on next access.
retrieveHeader(MessageProperties, String) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
 
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
 
run() - Method in class org.springframework.util.exec.ExecuteWatchdog
Watches the process and terminates it, if it runs for too long.
run() - Method in class org.springframework.util.exec.StreamPumper
Copies data from the input stream to the output stream.

S

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.
sendRPC(String, String, OtpErlangList) - Method in interface org.springframework.erlang.connection.Connection
Send an RPC request to the remote Erlang node.
sendRPC(String, String, OtpErlangList) - Method in class org.springframework.erlang.connection.DefaultConnection
 
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(AmqpAdmin...) - Method in class org.springframework.amqp.core.AbstractDeclarable
The AmqpAdmins 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.MessageProperties
 
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.
setBackingType(String) - Method in class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
 
setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
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.MessageProperties
 
setCodebaseUrl(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
Set the codebase URL to download classes from if not found locally.
setCommandline(String[]) - Method in class org.springframework.util.exec.Execute
Sets the commandline of the subprocess to launch.
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
 
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
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.erlang.support.ErlangAccessor
 
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
 
setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
 
setContentLength(long) - Method in class org.springframework.amqp.core.MessageProperties
 
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.
setCorrelationId(byte[]) - Method in class org.springframework.amqp.core.MessageProperties
 
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.
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.
setDefaultType(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
The type returned by DefaultClassMapper.toClass(MessageProperties) if no type information is found in the message properties.
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.MessageProperties
 
setDeliveryTag(long) - Method in class org.springframework.amqp.core.MessageProperties
 
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
 
setDontkill(boolean) - Method in class org.springframework.util.exec.ExecuteWatchdog
 
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.
setEnvironment(String[]) - Method in class org.springframework.util.exec.Execute
Sets the environment variables for the subprocess to launch.
setErlangConverter(ErlangConverter) - Method in class org.springframework.erlang.core.ErlangTemplate
 
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.
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
 
setExecutor(Executor) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
Provide an Executor for use by the Rabbit ConnectionFactory when creating connections.
setExitValue(int) - Method in class org.springframework.util.exec.Execute
 
setExpiration(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Set whether to expose the listener Rabbit Channel to a registered ChannelAwareMessageListener as well as to RabbitTemplate calls.
setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
 
setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageProperties
 
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
 
setImmediate(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
Deprecated.
- RabbitMQ no longer supports this option when publishing messages.
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.
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.
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.MessageProperties
 
setMessageId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setMessageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
 
setMessageKeyGeneretor(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
Set the MessagePropertiesConverter for this template.
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Set the MessagePropertiesConverter for this listener container.
setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
 
setNewenvironment(boolean) - Method in class org.springframework.util.exec.Execute
Set whether to propagate the default environment or not.
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.MessageProperties
 
setProcessErrorStream(InputStream) - Method in interface org.springframework.util.exec.ExecuteStreamHandler
Install a handler for the error stream of the subprocess.
setProcessErrorStream(InputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
 
setProcessInputStream(OutputStream) - Method in interface org.springframework.util.exec.ExecuteStreamHandler
Install a handler for the input stream of the subprocess.
setProcessInputStream(OutputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
 
setProcessOutputStream(InputStream) - Method in interface org.springframework.util.exec.ExecuteStreamHandler
Install a handler for the output stream of the subprocess.
setProcessOutputStream(InputStream) - Method in class org.springframework.util.exec.PumpStreamHandler
 
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 to receive messages from.
setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
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.
setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageProperties
 
setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
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.MessageProperties
 
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.MessageProperties
 
setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageProperties
 
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
 
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.
setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
 
setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageProperties
 
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.MessageProperties
 
setUniqueSelfNodeName(boolean) - Method in class org.springframework.erlang.connection.SimpleConnectionFactory
 
setUniqueSelfNodeName(boolean) - Method in class org.springframework.erlang.connection.SingleConnectionFactory
 
setUnmarshaller(Unmarshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
Set the Unmarshaller to be used by this message converter.
setUpstreamSet(String) - Method in class org.springframework.amqp.core.FederatedExchange
Deprecated.
 
setUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
 
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
 
setWorkingDirectory(File) - Method in class org.springframework.util.exec.Execute
Sets the working directory of the process to execute.
sharedConnectionEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Always use a shared Rabbit Connection.
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
Stop the shared Connection, call AbstractMessageListenerContainer.doShutdown(), and close this container.
SimpleConnection - Class in org.springframework.amqp.rabbit.connection
Simply a Connection.
SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
 
SimpleConnectionFactory - Class in org.springframework.erlang.connection
A simple implementation of ConnectionFactory that return a new connection for each invocation of the createConnection method.
SimpleConnectionFactory(String, String, String) - Constructor for class org.springframework.erlang.connection.SimpleConnectionFactory
 
SimpleConnectionFactory(String, String) - Constructor for class org.springframework.erlang.connection.SimpleConnectionFactory
 
SimpleErlangConverter - Class in org.springframework.erlang.support.converter
Converter that supports the basic types and arrays.
SimpleErlangConverter() - Constructor for class org.springframework.erlang.support.converter.SimpleErlangConverter
 
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
 
SingleConnectionFactory - Class in org.springframework.erlang.connection
A ConnectionFactory implementation that returns the same Connections from all SingleConnectionFactory.createConnection() calls, and ignores calls to Connection.close().
SingleConnectionFactory(String, String, String) - Constructor for class org.springframework.erlang.connection.SingleConnectionFactory
 
SingleConnectionFactory(String, String) - Constructor for class org.springframework.erlang.connection.SingleConnectionFactory
 
start() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Start this container.
start() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
start() - Method in interface org.springframework.util.exec.ExecuteStreamHandler
Start handling of the streams.
start(Process, Thread) - Method in class org.springframework.util.exec.ExecuteWatchdog
Watches the given process and terminates it, if it runs for too long.
start() - Method in class org.springframework.util.exec.PumpStreamHandler
 
startSenders() - Method in class org.springframework.amqp.rabbit.log4j.AmqpAppender
Submit the required number of senders into the pool.
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
 
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
 
stop() - Method in interface org.springframework.util.exec.ExecuteStreamHandler
Stop handling of the streams - will not be restarted.
stop() - Method in class org.springframework.util.exec.ExecuteWatchdog
Stops the watcher.
stop() - Method in class org.springframework.util.exec.PumpStreamHandler
 
StreamPumper - Class in org.springframework.util.exec
Copies all data from an input stream to an output stream.
StreamPumper(InputStream, OutputStream) - Constructor for class org.springframework.util.exec.StreamPumper
Create a new stream pumper.
SYSTEM - Static variable in class org.springframework.amqp.core.ExchangeTypes
 

T

TestUtils - Class in org.springframework.amqp.utils.test
See Spring Integration TestUtils.
TestUtils() - Constructor for class org.springframework.amqp.utils.test.TestUtils
 
to(FanoutExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(HeadersExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(DirectExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(TopicExchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
to(Exchange) - Method in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 
toClass(MessageProperties) - Method in interface org.springframework.amqp.support.converter.ClassMapper
 
toClass(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
 
toClass(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
toClass(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJavaTypeMapper
 
toErlang(Object) - Method in interface org.springframework.erlang.support.converter.ErlangConverter
Convert a Java object to a Erlang data type.
toErlang(Object) - Method in class org.springframework.erlang.support.converter.SimpleErlangConverter
 
toInt(MessageDeliveryMode) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
 
toJavaType(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
 
toJavaType(MessageProperties) - Method in class org.springframework.amqp.support.converter.DefaultJavaTypeMapper
 
toJavaType(MessageProperties) - Method in interface org.springframework.amqp.support.converter.Jackson2JavaTypeMapper
 
toJavaType(MessageProperties) - Method in interface org.springframework.amqp.support.converter.JavaTypeMapper
 
toMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
 
toMessage(Object, MessageProperties) - Method in interface org.springframework.amqp.support.converter.MessageConverter
Convert a Java object to a Message.
toMessageProperties(AMQP.BasicProperties, Envelope, String) - Method in class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
 
toMessageProperties(AMQP.BasicProperties, Envelope, String) - Method in interface org.springframework.amqp.rabbit.support.MessagePropertiesConverter
 
TOPIC - Static variable in class org.springframework.amqp.core.ExchangeTypes
 
TopicExchange - Class in org.springframework.amqp.core
Simple container collecting information to describe a topic exchange.
TopicExchange(String) - Constructor for class org.springframework.amqp.core.TopicExchange
 
TopicExchange(String, boolean, boolean) - Constructor for class org.springframework.amqp.core.TopicExchange
 
TopicExchange(String, boolean, boolean, Map<String, Object>) - Constructor for class org.springframework.amqp.core.TopicExchange
 
TopicExchangeParser - Class in org.springframework.amqp.rabbit.config
 
TopicExchangeParser() - Constructor for class org.springframework.amqp.rabbit.config.TopicExchangeParser
 
toString() - Method in class org.springframework.amqp.core.AbstractExchange
 
toString() - Method in class org.springframework.amqp.core.Address
 
toString() - Method in class org.springframework.amqp.core.Binding
 
toString() - Method in class org.springframework.amqp.core.Message
 
toString() - Method in class org.springframework.amqp.core.Queue
 
toString() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
 
toString() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
 
toString() - Method in class org.springframework.amqp.rabbit.support.CorrelationData
 
toString() - Method in class org.springframework.amqp.rabbit.support.PendingConfirm
 
toString() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
toString() - Method in class org.springframework.erlang.core.Application
 
toString() - Method in class org.springframework.erlang.core.Node
 
txCommit() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
txRollback() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
txSelect() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
type - Variable in class org.springframework.amqp.core.BindingBuilder.DestinationConfigurer
 

U

UncategorizedAmqpException - Exception in org.springframework.amqp
A "catch-all" exception type within the AmqpException hierarchy when no more specific cause is known.
UncategorizedAmqpException(Throwable) - Constructor for exception org.springframework.amqp.UncategorizedAmqpException
 
UncategorizedAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.UncategorizedAmqpException
 
UncategorizedOtpException - Exception in org.springframework.erlang
A "catch-all" exception type within the OtpException hierarchy when no more specific cause is known.
UncategorizedOtpException(Throwable) - Constructor for exception org.springframework.erlang.UncategorizedOtpException
 
UncategorizedOtpException(String, Throwable) - Constructor for exception org.springframework.erlang.UncategorizedOtpException
 
UniquelyNamedQueue - Class in org.springframework.amqp.core
Create a queue with a unique name.
UniquelyNamedQueue() - Constructor for class org.springframework.amqp.core.UniquelyNamedQueue
Create a uniquely named queue.
UniquelyNamedQueue(String) - Constructor for class org.springframework.amqp.core.UniquelyNamedQueue
Create a uniquely named queue with a fixed prefix.
unRegisterConsumerChannel() - Static method in class org.springframework.amqp.rabbit.connection.ConsumerChannelRegistry
See registerConsumerChannel.

V

validateConfiguration() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
Validate the configuration of this container.
validateConfiguration() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
Avoid the possibility of not configuring the CachingConnectionFactory in sync with the number of concurrent consumers.
valueOf(String) - Static method in enum org.springframework.amqp.core.AcknowledgeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.Binding.DestinationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.amqp.core.AcknowledgeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.Binding.DestinationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.amqp.core.MessageDeliveryMode
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitFor(Process) - Method in class org.springframework.util.exec.Execute
 
waitForConfirms() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirms(long) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie() - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
waitForConfirmsOrDie(long) - Method in class org.springframework.amqp.rabbit.support.PublisherCallbackChannelImpl
 
where(String) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAll(String...) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAll(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAny(String...) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
whereAny(Map<String, Object>) - Method in class org.springframework.amqp.core.BindingBuilder.HeadersExchangeMapConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.GenericExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.GenericExchangeRoutingKeyConfigurer
 
with(String) - Method in class org.springframework.amqp.core.BindingBuilder.TopicExchangeRoutingKeyConfigurer
 
with(Enum<?>) - Method in class org.springframework.amqp.core.BindingBuilder.TopicExchangeRoutingKeyConfigurer
 
withQueueName() - Method in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
 
wrapToListenerExecutionFailedExceptionIfNeeded(Exception) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Spring AMQP