All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
| Class |
Description |
| AbstractAdaptableMessageListener |
An abstract MessageListener adapter providing the
necessary infrastructure to extract the payload of a Message.
|
| AbstractAdaptableMessageListener.ReplyExpressionRoot |
Root object for reply expression evaluation.
|
| AbstractConnectionFactory |
|
| AbstractConnectionFactory.AddressShuffleMode |
The mode used to shuffle the addresses.
|
| AbstractExchangeParser |
|
| AbstractMessageListenerContainer |
|
| AbstractMessageListenerContainer.JavaLangErrorHandler |
A handler for Error on the container thread(s).
|
| AbstractMessageListenerContainer.SharedConnectionNotInitializedException |
Exception that indicates that the initial setup of this container's shared Rabbit Connection failed.
|
| AbstractMessageListenerContainer.WrappedTransactionException |
A runtime exception to wrap a Throwable.
|
| AbstractRabbitListenerContainerFactory<C extends AbstractMessageListenerContainer> |
|
| AbstractRabbitListenerEndpoint |
Base model for a Rabbit listener endpoint.
|
| AbstractRetryOperationsInterceptorFactoryBean |
Convenient base class for interceptor factories.
|
| AbstractRoutingConnectionFactory |
|
| ActiveObjectCounter<T> |
A mechanism to keep track of active objects.
|
| AfterCompletionFailedException |
Represents a failure to commit or rollback when performing afterCompletion
after the primary transaction completes.
|
| AmqpAppender |
A Log4j 2 appender that publishes logging events to an AMQP Exchange.
|
| AmqpAppender |
A Logback appender that publishes logging events to an AMQP Exchange.
|
| AmqpAppender.AmqpManager |
Manager class for the appender.
|
| AmqpAppender.Builder |
|
| AmqpAppender.Event |
Helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
|
| AmqpAppender.Event |
Small helper class to encapsulate a LoggingEvent, its MDC properties, and the number of retries.
|
| AmqpNackReceivedException |
An exception thrown when a negative acknowledgement received after publishing a
message.
|
| Argument |
Represents an argument used when declaring queues etc within a
QueueBinding.
|
| ArgumentBuilder |
A builder for argument maps.
|
| AsyncConsumerRestartedEvent |
An event that is published whenever a consumer is restarted.
|
| AsyncConsumerStartedEvent |
An event that is published whenever a new consumer is started.
|
| AsyncConsumerStoppedEvent |
An event that is published whenever a consumer is stopped (and not restarted).
|
| AsyncRabbitTemplate |
Provides asynchronous send and receive operations returning a ListenableFuture
allowing the caller to obtain the reply later, using get() or a callback.
|
| AutoRecoverConnectionNotCurrentlyOpenException |
An exception thrown if the connection is an auto recover connection that is not
currently open and is in the process of being recovered.
|
| BaseRabbitListenerContainerFactory<C extends MessageListenerContainer> |
Base abstract class for listener container factories.
|
| BatchingRabbitTemplate |
A RabbitTemplate that permits batching individual messages into a larger
message.
|
| BatchingStrategy |
Strategy for batching messages.
|
| BatchMessagingMessageListenerAdapter |
A listener adapter for batch listeners.
|
| BindingFactoryBean |
|
| BlockingQueueConsumer |
Specialized consumer encapsulating knowledge of the broker
connections and having its own lifecycle (start and stop).
|
| BrokerEvent |
Represents a broker event generated by the Event Exchange Plugin
(https://www.rabbitmq.com/event-exchange.html).
|
| BrokerEventListener |
When the event-exchange-plugin is enabled (see
https://www.rabbitmq.com/event-exchange.html), if an object of this type is declared as
a bean, selected events will be published as BrokerEvents.
|
| CachingConnectionFactory |
|
| CachingConnectionFactory.CacheMode |
The cache mode.
|
| CachingConnectionFactory.ConfirmType |
The type of publisher confirms to use.
|
| ChannelAwareBatchMessageListener |
Used to receive a batch of messages if the container supports it.
|
| ChannelAwareMessageListener |
A message listener that is aware of the Channel on which the message was received.
|
| ChannelCallback<T> |
Basic callback for use in RabbitTemplate.
|
| ChannelListener |
A listener for new channel creation and destruction.
|
| ChannelProxy |
Subinterface of Channel to be implemented by
Channel proxies.
|
| ClosingRecoveryListener |
A RecoveryListener that closes the recovered channel, to avoid
orphaned consumers.
|
| CompositeChannelListener |
|
| CompositeConnectionListener |
A composite listener that invokes its delegages in turn.
|
| ConditionalRejectingErrorHandler |
ErrorHandler that conditionally wraps the Exception in an
AmqpRejectAndDontRequeueException if the configured rejection
strategy determines that the message is fatal and should not be requeued.
|
| ConditionalRejectingErrorHandler.DefaultExceptionStrategy |
|
| Connection |
|
| ConnectionBlockedEvent |
The AmqpEvent emitted by the CachingConnectionFactory
when its connections are blocked.
|
| ConnectionFactory |
An interface based ConnectionFactory for creating Connections.
|
| ConnectionFactoryConfigurationUtils |
Utility methods for configuring connection factories.
|
| ConnectionFactoryContextWrapper |
Helper class to handle ConnectionFactory context binding and unbinding when executing instructions.
|
| ConnectionFactoryUtils |
Helper class for managing a Spring based Rabbit ConnectionFactory,
in particular for obtaining transactional Rabbit resources for a given ConnectionFactory.
|
| ConnectionFactoryUtils.ResourceFactory |
Callback interface for resource creation.
|
| ConnectionListener |
A listener for connection creation and closing.
|
| ConnectionNameStrategy |
A strategy to build an application-specific connection name,
which can be displayed in the management UI if RabbitMQ server supports it.
|
| ConnectionProxy |
Subinterface of Connection to be implemented by
Connection proxies.
|
| ConnectionUnblockedEvent |
The AmqpEvent emitted by the CachingConnectionFactory
when its connections are unblocked.
|
| ConsumeOkEvent |
An AmqpEvent emitted by the listener container
when consumer is subscribed to the queue.
|
| ConsumeOkNotReceivedException |
Thrown when a blocking receive operation is performed but the consumeOk
was not received before the receive timeout.
|
| ConsumerCancelledException |
Thrown when the broker cancels the consumer and the message
queue is drained.
|
| ConsumerChannelRegistry |
Consumers register their primary channels with this class.
|
| ContainerCustomizer<C extends MessageListenerContainer> |
Called by the container factory after the container is created and configured.
|
| ContainerUtils |
Utility methods for listener containers.
|
| CorrelationData |
Base class for correlating publisher confirms to sent messages.
|
| CorrelationData.Confirm |
Represents a publisher confirmation.
|
| CorrelationDataPostProcessor |
A callback invoked immediately before publishing a message to update, replace, or
create correlation data for publisher confirms.
|
| DeclarationExceptionEvent |
Application event published when a declaration exception occurs.
|
| DeclareExchangeConnectionListener |
A ConnectionListener that will declare a single exchange when the
connection is established.
|
| DefaultMessagePropertiesConverter |
|
| DelegatingInvocableHandler |
Delegates to an InvocableHandlerMethod based on the message payload type.
|
| Delivery |
Encapsulates an arbitrary message - simple "bean" holder structure.
|
| DirectExchangeParser |
|
| DirectMessageListenerContainer |
The SimpleMessageListenerContainer is not so simple.
|
| DirectRabbitListenerContainerFactory |
|
| DirectReplyToMessageListenerContainer |
Listener container for Direct ReplyTo only listens to the pseudo queue
Address.AMQ_RABBITMQ_REPLY_TO.
|
| DirectReplyToMessageListenerContainer.ChannelHolder |
Holder for a channel; contains a consumer epoch used to prevent inappropriate release
of the consumer after it has been allocated for reuse.
|
| EnableRabbit |
|
| Exchange |
An exchange to which to bind a RabbitListener queue.
|
| ExpressionFactoryBean |
FactoryBean for creating Expression instances.
|
| FanoutExchangeParser |
|
| FatalExceptionStrategy |
A strategy interface for the ConditionalRejectingErrorHandler to
decide whether an exception should be considered to be fatal and the
message should not be requeued.
|
| FatalListenerExecutionException |
Exception to be thrown when the execution of a listener method failed with an
irrecoverable problem.
|
| FatalListenerStartupException |
Exception to be thrown when the execution of a listener method failed on startup.
|
| HandlerAdapter |
|
| HeadersExchangeParser |
|
| ImmediateRequeueMessageRecoverer |
The MessageRecoverer implementation to throw an ImmediateRequeueAmqpException
for subsequent requeuing in the listener container.
|
| InvocationResult |
The result of a listener method invocation.
|
| ListenerContainerAware |
MessageListeners that also implement this
interface can have configuration verified during initialization.
|
| ListenerContainerConsumerFailedEvent |
Published when a listener consumer fails.
|
| ListenerContainerConsumerTerminatedEvent |
Published when a listener consumer is terminated.
|
| ListenerContainerFactoryBean |
A Factory bean to create a listener container.
|
| ListenerContainerFactoryBean.Type |
The container type.
|
| ListenerContainerIdleEvent |
An event that is emitted when a container is idle if the container
is configured to do so.
|
| ListenerExecutionFailedException |
Exception to be thrown when the execution of a listener method failed.
|
| ListenerFailedRuleBasedTransactionAttribute |
|
| LocalizedQueueConnectionFactory |
A RoutingConnectionFactory that determines the node on which a queue is located and
returns a factory that connects directly to that node.
|
| MessageBatch |
An object encapsulating a Message containing the batch of messages,
the exchange, and routing key.
|
| MessageBatchRecoverer |
A retry recoverer for use with a batch listener.
|
| MessageKeyGenerator |
|
| MessageListenerAdapter |
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with
flexible message type conversion.
|
| MessageListenerContainer |
Internal abstraction used by the framework representing a message
listener container.
|
| MessagePropertiesConverter |
Strategy interface for converting between Spring AMQP MessageProperties
and RabbitMQ BasicProperties.
|
| MessageRecoverer |
Implementations of this interface can handle failed messages after retries are
exhausted.
|
| MessageRejectedWhileStoppingException |
Exception class that indicates a rejected message on shutdown.
|
| MessagingMessageListenerAdapter |
|
| MethodRabbitListenerEndpoint |
|
| MethodRabbitListenerEndpoint.AdapterProvider |
Provider of listener adapters.
|
| MissingQueueEvent |
Event published when a missing queue is detected.
|
| MultiMethodRabbitListenerEndpoint |
|
| MultiRabbitBootstrapConfiguration |
|
| MultiRabbitListenerAnnotationBeanPostProcessor |
An extension of RabbitListenerAnnotationBeanPostProcessor that indicates the proper
RabbitAdmin bean to be used when processing to the listeners, and also associates it to the
declarables (Exchanges, Queues, and Bindings) returned.
|
| NamespaceUtils |
Shared utility methods for namespace parsers.
|
| NewMessageIdentifier |
An optimization for stateful retry of message processing.
|
| PendingConfirm |
Instances of this object track pending publisher confirms.
|
| PooledChannelConnectionFactory |
A very simple connection factory that caches channels using Apache Pool2
GenericObjectPools (one for transactional and one for non-transactional
channels).
|
| PublisherCallbackChannel |
Instances of this interface support a single listener being
registered for publisher confirms with multiple channels,
by adding context to the callbacks.
|
| PublisherCallbackChannel.Listener |
Listeners implementing this interface can participate
in publisher confirms received from multiple channels,
by invoking addListener on each channel.
|
| PublisherCallbackChannelFactory |
|
| PublisherCallbackChannelImpl |
Channel wrapper to allow a single listener able to handle
confirms from multiple channels.
|
| Queue |
A queue definition used within the bindings attribute of a QueueBinding.
|
| QueueBinding |
Defines a queue, the exchange it is to be bound to, and an optional binding key; used
with @RabbitListener.
|
| QueueParser |
|
| QueuesNotAvailableException |
This exception indicates that a consumer could not be started because none of
its queues are available for listening.
|
| RabbitAccessor |
|
| RabbitAdmin |
RabbitMQ implementation of portable AMQP administrative operations for AMQP >= 0.9.1.
|
| RabbitAdminEvent |
Base class for admin events.
|
| RabbitBootstrapConfiguration |
|
| RabbitConnectionFactoryBean |
Factory bean to create a RabbitMQ ConnectionFactory, delegating most setter methods and
optionally enabling SSL, with or without certificate validation.
|
| RabbitExceptionTranslator |
Translates Rabbit Exceptions to the AmqpException class
hierarchy.
|
| RabbitGatewaySupport |
Convenient super class for application classes that need RabbitMQ access.
|
| RabbitHandler |
Annotation that marks a method to be the target of a Rabbit message
listener within a class that is annotated with RabbitListener.
|
| RabbitListener |
|
| RabbitListenerAnnotationBeanPostProcessor |
Bean post-processor that registers methods annotated with RabbitListener
to be invoked by a AMQP message listener container created under the cover
by a RabbitListenerContainerFactory
according to the parameters of the annotation.
|
| RabbitListenerConfigurationSelector |
|
| RabbitListenerConfigurer |
Optional interface to be implemented by Spring managed bean willing
to customize how Rabbit listener endpoints are configured.
|
| RabbitListenerConfigUtils |
Configuration constants for internal sharing across subpackages.
|
| RabbitListenerContainerFactory<C extends MessageListenerContainer> |
|
| RabbitListenerEndpoint |
Model for a Rabbit listener endpoint.
|
| RabbitListenerEndpointRegistrar |
|
| RabbitListenerEndpointRegistry |
|
| RabbitListenerErrorHandler |
An error handler which is called when a {code @RabbitListener} method
throws an exception.
|
| RabbitListeners |
Container annotation that aggregates several RabbitListener annotations.
|
| RabbitMessageOperations |
A specialization of MessageSendingOperations and MessageRequestReplyOperations
for AMQP related operations that allow to specify not only the exchange but also the
routing key to use.
|
| RabbitMessagingTemplate |
|
| RabbitNamespaceHandler |
Namespace handler for Rabbit.
|
| RabbitNamespaceUtils |
|
| RabbitOperations |
Rabbit specific methods for Amqp functionality.
|
| RabbitOperations.OperationsCallback<T> |
Callback for using the same channel for multiple RabbitTemplate
operations.
|
| RabbitResourceHolder |
Rabbit resource holder, wrapping a RabbitMQ Connection and Channel.
|
| RabbitTemplate |
Helper class that simplifies synchronous RabbitMQ access (sending and receiving messages).
|
| RabbitTemplate.ConfirmCallback |
A callback for publisher confirmations.
|
| RabbitTemplate.ReturnCallback |
Deprecated.
|
| RabbitTemplate.ReturnsCallback |
A callback for returned messages.
|
| RabbitTemplate.TemplateConsumer |
|
| RabbitTransactionManager |
|
| RabbitUtils |
|
| RejectAndDontRequeueRecoverer |
MessageRecover that causes the listener container to reject
the message without requeuing.
|
| ReplyFailureException |
Exception to be thrown when the reply of a message failed to be sent.
|
| ReplyingMessageListener<T,R> |
|
| ReplyPostProcessor |
A post processor for replies.
|
| RepublishMessageRecoverer |
MessageRecoverer implementation that republishes recovered messages
to a specified exchange with the exception stack trace stored in the
message header x-exception.
|
| RepublishMessageRecovererWithConfirms |
|
| RetryInterceptorBuilder<B extends RetryInterceptorBuilder<B,T>,T extends org.aopalliance.intercept.MethodInterceptor> |
Simplified facade to make it easier and simpler to build a
StatefulRetryOperationsInterceptor or
(stateless) RetryOperationsInterceptor
by providing a fluent interface to defining the behavior on error.
|
| RetryInterceptorBuilder.StatefulRetryInterceptorBuilder |
Builder for a stateful interceptor.
|
| RetryInterceptorBuilder.StatelessRetryInterceptorBuilder |
Builder for a stateless interceptor.
|
| RoutingConnectionFactory |
Implementations select a connection factory based on a supplied key.
|
| ShutDownChannelListener |
Functional sub interface enabling a lambda for the onShutDown method.
|
| SimpleBatchingStrategy |
A simple batching strategy that supports only one exchange/routingKey; includes a batch
size, a batched message size limit and a timeout.
|
| SimpleConnection |
Simply a Connection.
|
| SimpleMessageListenerContainer |
|
| SimplePropertyValueConnectionNameStrategy |
|
| SimpleRabbitListenerContainerFactory |
|
| SimpleRabbitListenerEndpoint |
A RabbitListenerEndpoint simply
providing the MessageListener to invoke to process an incoming message for this
endpoint.
|
| SimpleResourceHolder |
Central helper that manages resources per thread to be used by resource management
code.
|
| SimpleRoutingConnectionFactory |
|
| StatefulRetryOperationsInterceptorFactoryBean |
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.
|
| StatelessRetryOperationsInterceptorFactoryBean |
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.
|
| ThreadChannelConnectionFactory |
A very simple connection factory that caches a channel per thread.
|
| TopicExchangeParser |
|
| ValueExpression<V> |
A very simple hardcoded implementation of the Expression
interface that represents an immutable value.
|