JavaScript is disabled on your browser.
Skip navigation links
Overview
Package
Class
Tree
Deprecated
Index
Help
Spring AMQP
Prev
Next
Frames
No Frames
All Classes
Hierarchy For All Packages
Package Hierarchies:
org.springframework.amqp
,
org.springframework.amqp.core
,
org.springframework.amqp.event
,
org.springframework.amqp.rabbit
,
org.springframework.amqp.rabbit.annotation
,
org.springframework.amqp.rabbit.batch
,
org.springframework.amqp.rabbit.config
,
org.springframework.amqp.rabbit.connection
,
org.springframework.amqp.rabbit.core
,
org.springframework.amqp.rabbit.junit
,
org.springframework.amqp.rabbit.listener
,
org.springframework.amqp.rabbit.listener.adapter
,
org.springframework.amqp.rabbit.listener.api
,
org.springframework.amqp.rabbit.listener.exception
,
org.springframework.amqp.rabbit.listener.support
,
org.springframework.amqp.rabbit.log4j2
,
org.springframework.amqp.rabbit.logback
,
org.springframework.amqp.rabbit.retry
,
org.springframework.amqp.rabbit.support
,
org.springframework.amqp.rabbit.test
,
org.springframework.amqp.rabbit.test.context
,
org.springframework.amqp.rabbit.test.mockito
,
org.springframework.amqp.rabbit.transaction
,
org.springframework.amqp.remoting.client
,
org.springframework.amqp.remoting.service
,
org.springframework.amqp.support
,
org.springframework.amqp.support.converter
,
org.springframework.amqp.support.postprocessor
,
org.springframework.amqp.utils
,
org.springframework.amqp.utils.test
Class Hierarchy
java.lang.
Object
org.springframework.amqp.rabbit.listener.adapter.
AbstractAdaptableMessageListener
(implements org.springframework.amqp.rabbit.listener.api.
ChannelAwareMessageListener
)
org.springframework.amqp.rabbit.listener.adapter.
MessageListenerAdapter
org.springframework.amqp.rabbit.listener.adapter.
MessagingMessageListenerAdapter
org.springframework.amqp.rabbit.listener.adapter.
BatchMessagingMessageListenerAdapter
(implements org.springframework.amqp.rabbit.listener.api.
ChannelAwareBatchMessageListener
)
org.springframework.amqp.rabbit.listener.adapter.
AbstractAdaptableMessageListener.ReplyExpressionRoot
org.springframework.beans.factory.xml.
AbstractBeanDefinitionParser
(implements org.springframework.beans.factory.xml.
BeanDefinitionParser
)
org.springframework.beans.factory.xml.
AbstractSingleBeanDefinitionParser
org.springframework.amqp.rabbit.config.
AbstractExchangeParser
org.springframework.amqp.rabbit.config.
DirectExchangeParser
org.springframework.amqp.rabbit.config.
FanoutExchangeParser
org.springframework.amqp.rabbit.config.
HeadersExchangeParser
org.springframework.amqp.rabbit.config.
TopicExchangeParser
org.springframework.amqp.rabbit.config.
QueueParser
org.springframework.amqp.core.
AbstractBuilder
org.springframework.amqp.core.
ExchangeBuilder
org.springframework.amqp.core.
QueueBuilder
org.springframework.amqp.support.postprocessor.
AbstractCompressingPostProcessor
(implements org.springframework.amqp.core.
MessagePostProcessor
, org.springframework.core.
Ordered
)
org.springframework.amqp.support.postprocessor.
AbstractDeflaterPostProcessor
org.springframework.amqp.support.postprocessor.
DeflaterPostProcessor
org.springframework.amqp.support.postprocessor.
GZipPostProcessor
org.springframework.amqp.support.postprocessor.
ZipPostProcessor
org.springframework.amqp.rabbit.connection.
AbstractConnectionFactory
(implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.context.
ApplicationListener
<E>, org.springframework.beans.factory.
BeanNameAware
, org.springframework.amqp.rabbit.connection.
ConnectionFactory
, org.springframework.beans.factory.
DisposableBean
, com.rabbitmq.client.ShutdownListener)
org.springframework.amqp.rabbit.connection.
CachingConnectionFactory
(implements org.springframework.beans.factory.
InitializingBean
, com.rabbitmq.client.ShutdownListener)
org.springframework.amqp.rabbit.connection.
PooledChannelConnectionFactory
(implements com.rabbitmq.client.ShutdownListener)
org.springframework.amqp.rabbit.connection.
ThreadChannelConnectionFactory
(implements com.rabbitmq.client.ShutdownListener)
org.springframework.amqp.core.
AbstractDeclarable
(implements org.springframework.amqp.core.
Declarable
)
org.springframework.amqp.core.
AbstractExchange
(implements org.springframework.amqp.core.
Exchange
)
org.springframework.amqp.core.
CustomExchange
org.springframework.amqp.core.
DirectExchange
org.springframework.amqp.core.
FanoutExchange
org.springframework.amqp.core.
HeadersExchange
org.springframework.amqp.core.
TopicExchange
org.springframework.amqp.core.
Binding
org.springframework.amqp.core.
Queue
(implements java.lang.
Cloneable
)
org.springframework.amqp.core.
AnonymousQueue
org.springframework.amqp.support.postprocessor.
AbstractDecompressingPostProcessor
(implements org.springframework.amqp.core.
MessagePostProcessor
, org.springframework.core.
Ordered
)
org.springframework.amqp.support.postprocessor.
GUnzipPostProcessor
org.springframework.amqp.support.postprocessor.
InflaterPostProcessor
org.springframework.amqp.support.postprocessor.
UnzipPostProcessor
org.springframework.beans.factory.config.
AbstractFactoryBean
<T> (implements org.springframework.beans.factory.
BeanClassLoaderAware
, org.springframework.beans.factory.
BeanFactoryAware
, org.springframework.beans.factory.
DisposableBean
, org.springframework.beans.factory.
FactoryBean
<T>, org.springframework.beans.factory.
InitializingBean
)
org.springframework.amqp.rabbit.support.
ExpressionFactoryBean
org.springframework.amqp.rabbit.config.
ListenerContainerFactoryBean
(implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.beans.factory.
BeanNameAware
, org.springframework.context.
SmartLifecycle
)
org.springframework.amqp.rabbit.connection.
RabbitConnectionFactoryBean
org.springframework.messaging.support.
AbstractHeaderMapper
<T> (implements org.springframework.messaging.support.
HeaderMapper
<T>)
org.springframework.amqp.support.
SimpleAmqpHeaderMapper
(implements org.springframework.amqp.support.
AmqpHeaderMapper
)
org.springframework.amqp.support.converter.
AbstractJavaTypeMapper
(implements org.springframework.beans.factory.
BeanClassLoaderAware
)
org.springframework.amqp.support.converter.
DefaultJackson2JavaTypeMapper
(implements org.springframework.amqp.support.converter.
Jackson2JavaTypeMapper
)
org.apache.logging.log4j.core.AbstractLifeCycle (implements org.apache.logging.log4j.core.LifeCycle2)
org.apache.logging.log4j.core.filter.AbstractFilterable (implements org.apache.logging.log4j.core.filter.Filterable)
org.apache.logging.log4j.core.appender.AbstractAppender (implements org.apache.logging.log4j.core.Appender, org.apache.logging.log4j.core.impl.LocationAware)
org.springframework.amqp.rabbit.log4j2.
AmqpAppender
org.apache.logging.log4j.core.appender.AbstractManager (implements java.lang.
AutoCloseable
)
org.springframework.amqp.rabbit.log4j2.
AmqpAppender.AmqpManager
org.springframework.amqp.support.converter.
AbstractMessageConverter
(implements org.springframework.amqp.support.converter.
MessageConverter
)
org.springframework.amqp.support.converter.
AbstractJackson2MessageConverter
(implements org.springframework.beans.factory.
BeanClassLoaderAware
, org.springframework.amqp.support.converter.
SmartMessageConverter
)
org.springframework.amqp.support.converter.
Jackson2JsonMessageConverter
org.springframework.amqp.support.converter.
Jackson2XmlMessageConverter
org.springframework.amqp.support.converter.
AllowedListDeserializingMessageConverter
org.springframework.amqp.support.converter.
SerializerMessageConverter
org.springframework.amqp.support.converter.
SimpleMessageConverter
(implements org.springframework.beans.factory.
BeanClassLoaderAware
)
org.springframework.amqp.support.converter.
MarshallingMessageConverter
(implements org.springframework.beans.factory.
InitializingBean
)
org.springframework.messaging.core.
AbstractMessageSendingTemplate
<D> (implements org.springframework.messaging.core.
MessageSendingOperations
<D>)
org.springframework.messaging.core.
AbstractMessageReceivingTemplate
<D> (implements org.springframework.messaging.core.
MessageReceivingOperations
<D>)
org.springframework.messaging.core.
AbstractMessagingTemplate
<D> (implements org.springframework.messaging.core.
MessageRequestReplyOperations
<D>)
org.springframework.amqp.rabbit.core.
RabbitMessagingTemplate
(implements org.springframework.beans.factory.
InitializingBean
, org.springframework.amqp.rabbit.core.
RabbitMessageOperations
)
org.springframework.transaction.support.
AbstractPlatformTransactionManager
(implements org.springframework.transaction.
PlatformTransactionManager
, java.io.
Serializable
)
org.springframework.amqp.rabbit.transaction.
RabbitTransactionManager
(implements org.springframework.beans.factory.
InitializingBean
, org.springframework.transaction.support.
ResourceTransactionManager
)
org.springframework.amqp.rabbit.config.
AbstractRabbitListenerContainerFactory
<C> (implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.amqp.rabbit.listener.
RabbitListenerContainerFactory
<C>)
org.springframework.amqp.rabbit.config.
DirectRabbitListenerContainerFactory
org.springframework.amqp.rabbit.config.
SimpleRabbitListenerContainerFactory
org.springframework.amqp.rabbit.listener.
AbstractRabbitListenerEndpoint
(implements org.springframework.beans.factory.
BeanFactoryAware
, org.springframework.amqp.rabbit.listener.
RabbitListenerEndpoint
)
org.springframework.amqp.rabbit.listener.
MethodRabbitListenerEndpoint
org.springframework.amqp.rabbit.listener.
MultiMethodRabbitListenerEndpoint
org.springframework.amqp.rabbit.config.
SimpleRabbitListenerEndpoint
org.springframework.amqp.rabbit.config.
AbstractRetryOperationsInterceptorFactoryBean
(implements org.springframework.beans.factory.
FactoryBean
<T>)
org.springframework.amqp.rabbit.config.
StatefulRetryOperationsInterceptorFactoryBean
org.springframework.amqp.rabbit.config.
StatelessRetryOperationsInterceptorFactoryBean
org.springframework.amqp.rabbit.connection.
AbstractRoutingConnectionFactory
(implements org.springframework.amqp.rabbit.connection.
ConnectionFactory
, org.springframework.beans.factory.
InitializingBean
, org.springframework.amqp.rabbit.connection.
RoutingConnectionFactory
)
org.springframework.amqp.rabbit.connection.
SimpleRoutingConnectionFactory
org.springframework.amqp.rabbit.support.
ActiveObjectCounter
<T>
org.springframework.amqp.core.
Address
org.springframework.amqp.rabbit.log4j2.
AmqpAppender.Builder
(implements org.apache.logging.log4j.core.util.Builder<T>)
org.springframework.amqp.rabbit.logback.
AmqpAppender.Event
org.springframework.amqp.rabbit.log4j2.
AmqpAppender.Event
org.springframework.amqp.rabbit.logback.
AmqpAppender.EventSender
(implements java.lang.
Runnable
)
org.springframework.amqp.rabbit.log4j2.
AmqpAppender.EventSender
(implements java.lang.
Runnable
)
org.springframework.amqp.support.
AmqpHeaders
org.springframework.amqp.rabbit.
AsyncRabbitTemplate
(implements org.springframework.amqp.core.
AsyncAmqpTemplate
, org.springframework.beans.factory.
BeanNameAware
, org.springframework.amqp.rabbit.listener.api.
ChannelAwareMessageListener
, org.springframework.amqp.rabbit.core.
RabbitTemplate.ConfirmCallback
, org.springframework.amqp.rabbit.core.
RabbitTemplate.ReturnsCallback
, org.springframework.context.
SmartLifecycle
)
org.springframework.amqp.core.
Base64UrlNamingStrategy
(implements org.springframework.amqp.core.
NamingStrategy
)
org.springframework.amqp.core.
BindingBuilder
org.springframework.amqp.core.
BindingBuilder.DestinationConfigurer
org.springframework.amqp.core.
BindingBuilder.DirectExchangeRoutingKeyConfigurer
org.springframework.amqp.core.
BindingBuilder.GenericArgumentsConfigurer
org.springframework.amqp.core.
BindingBuilder.GenericExchangeRoutingKeyConfigurer
org.springframework.amqp.core.
BindingBuilder.HeadersExchangeMapConfigurer
org.springframework.amqp.core.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeKeysBindingCreator
org.springframework.amqp.core.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeMapBindingCreator
org.springframework.amqp.core.
BindingBuilder.HeadersExchangeMapConfigurer.HeadersExchangeSingleValueBindingCreator
org.springframework.amqp.core.
BindingBuilder.TopicExchangeRoutingKeyConfigurer
org.springframework.amqp.rabbit.config.
BindingFactoryBean
(implements org.springframework.beans.factory.
FactoryBean
<T>)
org.springframework.amqp.rabbit.listener.
BlockingQueueConsumer
org.springframework.amqp.rabbit.core.
BrokerEventListener
(implements org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.amqp.rabbit.connection.
ConnectionListener
, org.springframework.amqp.core.
MessageListener
, org.springframework.context.
SmartLifecycle
)
org.springframework.amqp.rabbit.junit.
BrokerRunningSupport
org.springframework.amqp.rabbit.junit.
BrokerTestUtils
org.springframework.amqp.rabbit.connection.
ClosingRecoveryListener
(implements com.rabbitmq.client.RecoveryListener)
org.springframework.amqp.rabbit.connection.
CompositeChannelListener
(implements org.springframework.amqp.rabbit.connection.
ChannelListener
)
org.springframework.amqp.rabbit.connection.
CompositeConnectionListener
(implements org.springframework.amqp.rabbit.connection.
ConnectionListener
)
org.springframework.amqp.rabbit.listener.
ConditionalRejectingErrorHandler
(implements org.springframework.util.
ErrorHandler
)
org.springframework.amqp.rabbit.listener.
ConditionalRejectingErrorHandler.DefaultExceptionStrategy
(implements org.springframework.amqp.rabbit.listener.
FatalExceptionStrategy
)
org.springframework.amqp.rabbit.connection.
ConnectionFactoryConfigurationUtils
org.springframework.amqp.rabbit.connection.
ConnectionFactoryContextWrapper
org.springframework.amqp.rabbit.connection.
ConnectionFactoryUtils
org.springframework.amqp.rabbit.connection.
ConsumerChannelRegistry
org.springframework.amqp.rabbit.listener.support.
ContainerUtils
org.springframework.amqp.support.converter.
ContentTypeDelegatingMessageConverter
(implements org.springframework.amqp.support.converter.
MessageConverter
)
ch.qos.logback.core.spi.ContextAwareBase (implements ch.qos.logback.core.spi.ContextAware)
ch.qos.logback.core.AppenderBase<E> (implements ch.qos.logback.core.Appender<E>)
org.springframework.amqp.rabbit.logback.
AmqpAppender
org.springframework.amqp.rabbit.connection.
CorrelationData
(implements org.springframework.amqp.core.
Correlation
)
org.springframework.amqp.rabbit.connection.
CorrelationData.Confirm
org.springframework.amqp.core.
Declarables
org.springframework.amqp.rabbit.core.
DeclareExchangeConnectionListener
(implements org.springframework.amqp.rabbit.connection.
ConnectionListener
)
org.springframework.amqp.support.converter.
DefaultClassMapper
(implements org.springframework.amqp.support.converter.
ClassMapper
, org.springframework.beans.factory.
InitializingBean
)
com.rabbitmq.client.DefaultConsumer (implements com.rabbitmq.client.Consumer)
org.springframework.amqp.rabbit.core.
RabbitTemplate.TemplateConsumer
org.springframework.amqp.rabbit.support.
DefaultMessagePropertiesConverter
(implements org.springframework.amqp.rabbit.support.
MessagePropertiesConverter
)
org.springframework.transaction.support.
DefaultTransactionDefinition
(implements java.io.
Serializable
, org.springframework.transaction.
TransactionDefinition
)
org.springframework.transaction.interceptor.
DefaultTransactionAttribute
(implements org.springframework.transaction.interceptor.
TransactionAttribute
)
org.springframework.transaction.interceptor.
RuleBasedTransactionAttribute
(implements java.io.
Serializable
)
org.springframework.amqp.rabbit.listener.
ListenerFailedRuleBasedTransactionAttribute
org.springframework.amqp.support.postprocessor.
DelegatingDecompressingPostProcessor
(implements org.springframework.amqp.core.
MessagePostProcessor
, org.springframework.core.
Ordered
)
org.springframework.amqp.rabbit.listener.adapter.
DelegatingInvocableHandler
org.springframework.amqp.rabbit.support.
Delivery
org.springframework.amqp.rabbit.listener.
DirectReplyToMessageListenerContainer.ChannelHolder
java.util.
EventObject
(implements java.io.
Serializable
)
org.springframework.context.
ApplicationEvent
org.springframework.amqp.event.
AmqpEvent
org.springframework.amqp.rabbit.listener.
AsyncConsumerRestartedEvent
org.springframework.amqp.rabbit.listener.
AsyncConsumerStartedEvent
org.springframework.amqp.rabbit.listener.
AsyncConsumerStoppedEvent
org.springframework.amqp.rabbit.core.
BrokerEvent
org.springframework.amqp.rabbit.connection.
ConnectionBlockedEvent
org.springframework.amqp.rabbit.connection.
ConnectionUnblockedEvent
org.springframework.amqp.rabbit.listener.
ConsumeOkEvent
org.springframework.amqp.rabbit.listener.
ListenerContainerConsumerFailedEvent
org.springframework.amqp.rabbit.listener.
ListenerContainerConsumerTerminatedEvent
org.springframework.amqp.rabbit.listener.
ListenerContainerIdleEvent
org.springframework.amqp.rabbit.listener.
MissingQueueEvent
org.springframework.amqp.rabbit.core.
RabbitAdminEvent
org.springframework.amqp.rabbit.core.
DeclarationExceptionEvent
org.springframework.amqp.core.
ExchangeTypes
org.mockito.internal.stubbing.defaultanswers.ForwardsInvocations (implements org.mockito.stubbing.Answer<T>, java.io.
Serializable
)
org.springframework.amqp.rabbit.test.mockito.
LambdaAnswer
<T>
org.springframework.amqp.rabbit.test.mockito.
LatchCountDownAndCallRealMethodAnswer
org.springframework.amqp.rabbit.listener.adapter.
HandlerAdapter
org.springframework.amqp.rabbit.retry.
ImmediateRequeueMessageRecoverer
(implements org.springframework.amqp.rabbit.retry.
MessageRecoverer
)
org.springframework.amqp.rabbit.listener.adapter.
InvocationResult
org.springframework.amqp.utils.
JavaUtils
org.springframework.amqp.rabbit.junit.
JUnitUtils
org.springframework.amqp.rabbit.junit.
JUnitUtils.LevelsContainer
org.springframework.amqp.rabbit.connection.
LocalizedQueueConnectionFactory
(implements org.springframework.amqp.rabbit.connection.
ConnectionFactory
, org.springframework.beans.factory.
DisposableBean
, org.springframework.amqp.rabbit.connection.
RoutingConnectionFactory
)
org.springframework.amqp.rabbit.junit.
LogLevelAdjuster
(implements org.junit.rules.MethodRule)
org.springframework.amqp.rabbit.junit.
LogLevelsCondition
(implements org.junit.jupiter.api.extension.AfterAllCallback, org.junit.jupiter.api.extension.AfterEachCallback, org.junit.jupiter.api.extension.BeforeAllCallback, org.junit.jupiter.api.extension.BeforeEachCallback, org.junit.jupiter.api.extension.ExecutionCondition)
org.springframework.amqp.rabbit.junit.
LongRunningIntegrationTestCondition
(implements org.junit.jupiter.api.extension.ExecutionCondition)
org.springframework.amqp.utils.
MapBuilder
<B,K,V>
org.springframework.amqp.rabbit.support.
ArgumentBuilder
org.springframework.amqp.core.
Message
(implements java.io.
Serializable
)
org.springframework.amqp.rabbit.batch.
MessageBatch
org.springframework.amqp.core.
MessageBuilderSupport
<T>
org.springframework.amqp.core.
MessageBuilder
org.springframework.amqp.core.
MessagePropertiesBuilder
org.springframework.messaging.support.
MessageHeaderAccessor
org.springframework.messaging.support.
NativeMessageHeaderAccessor
org.springframework.amqp.support.
AmqpMessageHeaderAccessor
org.springframework.amqp.support.postprocessor.
MessagePostProcessorUtils
org.springframework.amqp.core.
MessageProperties
(implements java.io.
Serializable
)
org.springframework.amqp.support.converter.
MessagingMessageConverter
(implements org.springframework.beans.factory.
InitializingBean
, org.springframework.amqp.support.converter.
MessageConverter
)
org.springframework.amqp.rabbit.listener.adapter.
MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
org.springframework.amqp.rabbit.annotation.
MultiRabbitBootstrapConfiguration
(implements org.springframework.context.
EnvironmentAware
, org.springframework.context.annotation.
ImportBeanDefinitionRegistrar
)
org.springframework.beans.factory.xml.
NamespaceHandlerSupport
(implements org.springframework.beans.factory.xml.
NamespaceHandler
)
org.springframework.amqp.rabbit.config.
RabbitNamespaceHandler
org.springframework.amqp.rabbit.config.
NamespaceUtils
org.springframework.amqp.rabbit.connection.
PendingConfirm
org.springframework.amqp.support.converter.
ProjectingMessageConverter
org.springframework.amqp.rabbit.connection.
PublisherCallbackChannelImpl
(implements com.rabbitmq.client.ConfirmListener, org.springframework.amqp.rabbit.connection.
PublisherCallbackChannel
, com.rabbitmq.client.ReturnCallback, com.rabbitmq.client.ShutdownListener)
org.springframework.amqp.core.
QueueInformation
org.springframework.amqp.rabbit.connection.
RabbitAccessor
(implements org.springframework.beans.factory.
InitializingBean
)
org.springframework.amqp.rabbit.listener.
AbstractMessageListenerContainer
(implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.beans.factory.
BeanNameAware
, org.springframework.beans.factory.
DisposableBean
, org.springframework.amqp.rabbit.listener.
MessageListenerContainer
)
org.springframework.amqp.rabbit.listener.
DirectMessageListenerContainer
org.springframework.amqp.rabbit.listener.
DirectReplyToMessageListenerContainer
org.springframework.amqp.rabbit.listener.
SimpleMessageListenerContainer
org.springframework.amqp.rabbit.core.
RabbitTemplate
(implements org.springframework.beans.factory.
BeanFactoryAware
, org.springframework.beans.factory.
BeanNameAware
, org.springframework.amqp.rabbit.listener.api.
ChannelAwareMessageListener
, org.springframework.beans.factory.
DisposableBean
, org.springframework.amqp.rabbit.support.
ListenerContainerAware
, org.springframework.amqp.rabbit.connection.
PublisherCallbackChannel.Listener
, org.springframework.amqp.rabbit.core.
RabbitOperations
)
org.springframework.amqp.rabbit.core.
BatchingRabbitTemplate
org.springframework.amqp.rabbit.test.
TestRabbitTemplate
(implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationListener
<E>)
org.springframework.amqp.rabbit.core.
RabbitAdmin
(implements org.springframework.amqp.core.
AmqpAdmin
, org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationEventPublisherAware
, org.springframework.beans.factory.
BeanNameAware
, org.springframework.beans.factory.
InitializingBean
)
org.springframework.amqp.rabbit.junit.
RabbitAvailableCondition
(implements org.junit.jupiter.api.extension.AfterAllCallback, org.junit.jupiter.api.extension.AfterEachCallback, org.junit.jupiter.api.extension.ExecutionCondition, org.junit.jupiter.api.extension.ParameterResolver)
org.springframework.amqp.rabbit.annotation.
RabbitBootstrapConfiguration
(implements org.springframework.context.annotation.
ImportBeanDefinitionRegistrar
)
org.springframework.amqp.rabbit.support.
RabbitExceptionTranslator
org.springframework.amqp.rabbit.core.
RabbitGatewaySupport
(implements org.springframework.beans.factory.
InitializingBean
)
org.springframework.amqp.rabbit.annotation.
RabbitListenerAnnotationBeanPostProcessor
(implements org.springframework.beans.factory.
BeanClassLoaderAware
, org.springframework.beans.factory.
BeanFactoryAware
, org.springframework.beans.factory.config.
BeanPostProcessor
, org.springframework.context.
EnvironmentAware
, org.springframework.core.
Ordered
, org.springframework.beans.factory.
SmartInitializingSingleton
)
org.springframework.amqp.rabbit.annotation.
MultiRabbitListenerAnnotationBeanPostProcessor
org.springframework.amqp.rabbit.test.
RabbitListenerTestHarness
org.springframework.amqp.rabbit.annotation.
RabbitListenerConfigurationSelector
(implements org.springframework.context.annotation.
DeferredImportSelector
)
org.springframework.amqp.rabbit.test.
RabbitListenerTestSelector
org.springframework.amqp.rabbit.config.
RabbitListenerConfigUtils
org.springframework.amqp.rabbit.listener.
RabbitListenerEndpointRegistrar
(implements org.springframework.beans.factory.
BeanFactoryAware
, org.springframework.beans.factory.
InitializingBean
)
org.springframework.amqp.rabbit.listener.
RabbitListenerEndpointRegistry
(implements org.springframework.context.
ApplicationContextAware
, org.springframework.context.
ApplicationListener
<E>, org.springframework.beans.factory.
DisposableBean
, org.springframework.context.
SmartLifecycle
)
org.springframework.amqp.rabbit.test.
RabbitListenerTestBootstrap
(implements org.springframework.context.annotation.
ImportBeanDefinitionRegistrar
)
org.springframework.amqp.rabbit.test.
RabbitListenerTestHarness.InvocationData
org.springframework.amqp.rabbit.config.
RabbitNamespaceUtils
org.springframework.amqp.rabbit.connection.
RabbitUtils
org.springframework.amqp.rabbit.retry.
RejectAndDontRequeueRecoverer
(implements org.springframework.amqp.rabbit.retry.
MessageRecoverer
)
org.springframework.amqp.support.converter.
RemoteInvocationAwareMessageConverterAdapter
(implements org.springframework.beans.factory.
BeanClassLoaderAware
, org.springframework.amqp.support.converter.
MessageConverter
)
org.springframework.remoting.support.
RemotingSupport
(implements org.springframework.beans.factory.
BeanClassLoaderAware
)
org.springframework.remoting.support.
RemoteAccessor
org.springframework.amqp.remoting.client.
AmqpClientInterceptor
(implements org.aopalliance.intercept.
MethodInterceptor
)
org.springframework.amqp.remoting.client.
AmqpProxyFactoryBean
(implements org.springframework.beans.factory.
FactoryBean
<T>, org.springframework.beans.factory.
InitializingBean
)
org.springframework.remoting.support.
RemoteExporter
org.springframework.remoting.support.
RemoteInvocationBasedExporter
org.springframework.amqp.remoting.service.
AmqpInvokerServiceExporter
(implements org.springframework.amqp.core.
MessageListener
)
org.springframework.amqp.rabbit.retry.
RepublishMessageRecoverer
(implements org.springframework.amqp.rabbit.retry.
MessageRecoverer
)
org.springframework.amqp.rabbit.retry.
RepublishMessageRecovererWithConfirms
org.springframework.transaction.support.
ResourceHolderSupport
(implements org.springframework.transaction.support.
ResourceHolder
)
org.springframework.amqp.rabbit.connection.
RabbitResourceHolder
org.springframework.amqp.rabbit.config.
RetryInterceptorBuilder
<B,T>
org.springframework.amqp.rabbit.config.
RetryInterceptorBuilder.StatefulRetryInterceptorBuilder
org.springframework.amqp.rabbit.config.
RetryInterceptorBuilder.StatelessRetryInterceptorBuilder
org.springframework.amqp.core.
ReturnedMessage
org.springframework.amqp.support.
SendRetryContextAccessor
org.springframework.amqp.utils.
SerializationUtils
org.springframework.util.concurrent.
SettableListenableFuture
<T> (implements org.springframework.util.concurrent.
ListenableFuture
<T>)
org.springframework.amqp.rabbit.
AsyncRabbitTemplate.RabbitFuture
<T>
org.springframework.amqp.rabbit.
AsyncRabbitTemplate.RabbitConverterFuture
<C>
org.springframework.amqp.rabbit.
AsyncRabbitTemplate.RabbitMessageFuture
org.springframework.amqp.rabbit.batch.
SimpleBatchingStrategy
(implements org.springframework.amqp.rabbit.batch.
BatchingStrategy
)
org.springframework.amqp.rabbit.connection.
SimpleConnection
(implements org.springframework.amqp.rabbit.connection.
Connection
, com.rabbitmq.client.impl.NetworkConnection)
org.springframework.amqp.rabbit.connection.
SimplePropertyValueConnectionNameStrategy
(implements org.springframework.amqp.rabbit.connection.
ConnectionNameStrategy
, org.springframework.context.
EnvironmentAware
)
org.springframework.amqp.rabbit.connection.
SimpleResourceHolder
org.springframework.amqp.utils.test.
TestUtils
org.junit.rules.TestWatcher (implements org.junit.rules.TestRule)
org.springframework.amqp.rabbit.junit.
BrokerRunning
org.springframework.amqp.rabbit.junit.
LongRunningIntegrationTest
java.lang.
Throwable
(implements java.io.
Serializable
)
java.lang.
Exception
java.lang.
RuntimeException
org.springframework.amqp.rabbit.listener.
AbstractMessageListenerContainer.SharedConnectionNotInitializedException
org.springframework.amqp.rabbit.listener.
AbstractMessageListenerContainer.WrappedTransactionException
org.springframework.amqp.
AmqpException
org.springframework.amqp.
AmqpApplicationContextClosedException
org.springframework.amqp.
AmqpAuthenticationException
org.springframework.amqp.
AmqpConnectException
org.springframework.amqp.
AmqpIllegalStateException
org.springframework.amqp.
AmqpIOException
org.springframework.amqp.core.
AmqpMessageReturnedException
org.springframework.amqp.rabbit.core.
AmqpNackReceivedException
org.springframework.amqp.
AmqpRejectAndDontRequeueException
org.springframework.amqp.
AmqpRemoteException
org.springframework.amqp.core.
AmqpReplyTimeoutException
org.springframework.amqp.
AmqpResourceNotAvailableException
org.springframework.amqp.
AmqpTimeoutException
org.springframework.amqp.
AmqpUnsupportedEncodingException
org.springframework.amqp.rabbit.connection.
AutoRecoverConnectionNotCurrentlyOpenException
org.springframework.amqp.rabbit.core.
ConsumeOkNotReceivedException
org.springframework.amqp.rabbit.listener.exception.
FatalListenerExecutionException
org.springframework.amqp.rabbit.listener.exception.
FatalListenerStartupException
org.springframework.amqp.rabbit.listener.
QueuesNotAvailableException
org.springframework.amqp.
ImmediateAcknowledgeAmqpException
org.springframework.amqp.
ImmediateRequeueAmqpException
org.springframework.amqp.rabbit.support.
ListenerExecutionFailedException
org.springframework.amqp.support.converter.
MessageConversionException
org.springframework.amqp.rabbit.listener.exception.
MessageRejectedWhileStoppingException
org.springframework.amqp.rabbit.listener.adapter.
ReplyFailureException
org.springframework.amqp.
UncategorizedAmqpException
org.springframework.amqp.rabbit.junit.
BrokerRunningSupport.BrokerNotAliveException
org.springframework.amqp.rabbit.support.
ConsumerCancelledException
org.springframework.amqp.core.
UUIDNamingStrategy
(implements org.springframework.amqp.core.
NamingStrategy
)
org.springframework.amqp.rabbit.support.
ValueExpression
<V> (implements org.springframework.expression.
Expression
)
Interface Hierarchy
org.springframework.amqp.rabbit.listener.
AbstractMessageListenerContainer.JavaLangErrorHandler
org.springframework.amqp.core.
AmqpAdmin
org.springframework.amqp.core.
AmqpTemplate
org.springframework.amqp.rabbit.core.
RabbitOperations
(also extends org.springframework.context.
Lifecycle
)
org.springframework.amqp.core.
AsyncAmqpTemplate
java.lang.
AutoCloseable
com.rabbitmq.client.Channel (also extends com.rabbitmq.client.ShutdownNotifier)
org.springframework.amqp.rabbit.connection.
ChannelProxy
org.springframework.amqp.rabbit.connection.
PublisherCallbackChannel
org.springframework.amqp.rabbit.connection.
Connection
org.springframework.amqp.rabbit.connection.
ConnectionProxy
org.springframework.amqp.rabbit.batch.
BatchingStrategy
java.util.function.
BiFunction
<T,U,R>
org.springframework.amqp.rabbit.listener.adapter.
ReplyPostProcessor
org.springframework.amqp.rabbit.core.
ChannelCallback
<T>
org.springframework.amqp.rabbit.connection.
ChannelListener
org.springframework.amqp.rabbit.connection.
ShutDownChannelListener
org.springframework.amqp.support.converter.
ClassMapper
org.springframework.amqp.support.converter.
Jackson2JavaTypeMapper
org.springframework.amqp.support.
ConditionalExceptionLogger
org.springframework.amqp.rabbit.connection.
ConnectionFactory
org.springframework.amqp.rabbit.connection.
ConnectionFactoryUtils.ResourceFactory
org.springframework.amqp.rabbit.connection.
ConnectionListener
org.springframework.amqp.rabbit.connection.
ConnectionNameStrategy
org.springframework.amqp.support.
ConsumerTagStrategy
org.springframework.amqp.rabbit.config.
ContainerCustomizer
<C>
org.springframework.amqp.core.
Correlation
org.springframework.amqp.rabbit.core.
CorrelationDataPostProcessor
org.springframework.amqp.core.
Declarable
org.springframework.amqp.core.
Exchange
org.springframework.amqp.rabbit.listener.
FatalExceptionStrategy
java.util.function.
Function
<T,R>
org.springframework.amqp.core.
DeclarableCustomizer
org.springframework.messaging.support.
HeaderMapper
<T>
org.springframework.amqp.support.
AmqpHeaderMapper
org.springframework.amqp.rabbit.test.mockito.
LambdaAnswer.ValueToReturn
<T>
org.springframework.context.
Lifecycle
org.springframework.amqp.rabbit.core.
RabbitOperations
(also extends org.springframework.amqp.core.
AmqpTemplate
)
org.springframework.context.
SmartLifecycle
(also extends org.springframework.context.
Phased
)
org.springframework.amqp.rabbit.listener.
MessageListenerContainer
org.springframework.amqp.rabbit.support.
ListenerContainerAware
org.springframework.amqp.support.converter.
MessageConverter
org.springframework.amqp.support.converter.
SmartMessageConverter
org.springframework.amqp.rabbit.retry.
MessageKeyGenerator
org.springframework.amqp.core.
MessageListener
org.springframework.amqp.core.
BatchMessageListener
org.springframework.amqp.rabbit.listener.api.
ChannelAwareBatchMessageListener
org.springframework.amqp.rabbit.listener.api.
ChannelAwareMessageListener
org.springframework.amqp.rabbit.listener.api.
ChannelAwareBatchMessageListener
org.springframework.amqp.core.
MessagePostProcessor
org.springframework.amqp.rabbit.support.
MessagePropertiesConverter
org.springframework.messaging.core.
MessageReceivingOperations
<D>
org.springframework.amqp.rabbit.core.
RabbitMessageOperations
(also extends org.springframework.messaging.core.
MessageRequestReplyOperations
<D>, org.springframework.messaging.core.
MessageSendingOperations
<D>)
org.springframework.amqp.rabbit.retry.
MessageRecoverer
org.springframework.amqp.rabbit.retry.
MessageBatchRecoverer
org.springframework.messaging.core.
MessageRequestReplyOperations
<D>
org.springframework.amqp.rabbit.core.
RabbitMessageOperations
(also extends org.springframework.messaging.core.
MessageReceivingOperations
<D>, org.springframework.messaging.core.
MessageSendingOperations
<D>)
org.springframework.messaging.core.
MessageSendingOperations
<D>
org.springframework.amqp.rabbit.core.
RabbitMessageOperations
(also extends org.springframework.messaging.core.
MessageReceivingOperations
<D>, org.springframework.messaging.core.
MessageRequestReplyOperations
<D>)
org.springframework.amqp.core.
NamingStrategy
org.springframework.amqp.rabbit.retry.
NewMessageIdentifier
org.springframework.context.
Phased
org.springframework.context.
SmartLifecycle
(also extends org.springframework.context.
Lifecycle
)
org.springframework.amqp.rabbit.listener.
MessageListenerContainer
org.springframework.amqp.rabbit.connection.
PublisherCallbackChannel.Listener
org.springframework.amqp.rabbit.connection.
PublisherCallbackChannelFactory
org.springframework.amqp.rabbit.annotation.
RabbitListenerConfigurer
org.springframework.amqp.rabbit.listener.
RabbitListenerContainerFactory
<C>
org.springframework.amqp.rabbit.listener.
RabbitListenerEndpoint
org.springframework.amqp.rabbit.listener.api.
RabbitListenerErrorHandler
org.springframework.amqp.rabbit.core.
RabbitOperations.OperationsCallback
<T>
org.springframework.amqp.rabbit.core.
RabbitTemplate.ConfirmCallback
org.springframework.amqp.rabbit.core.
RabbitTemplate.ReturnCallback
org.springframework.amqp.rabbit.core.
RabbitTemplate.ReturnsCallback
org.springframework.amqp.core.
ReceiveAndReplyCallback
<R,S>
org.springframework.amqp.core.
ReceiveAndReplyMessageCallback
org.springframework.amqp.rabbit.listener.adapter.
ReplyingMessageListener
<T,R>
org.springframework.amqp.core.
ReplyToAddressCallback
<T>
org.springframework.amqp.rabbit.connection.
RoutingConnectionFactory
com.rabbitmq.client.ShutdownNotifier
com.rabbitmq.client.Channel (also extends java.lang.
AutoCloseable
)
org.springframework.amqp.rabbit.connection.
ChannelProxy
org.springframework.amqp.rabbit.connection.
PublisherCallbackChannel
Annotation Type Hierarchy
org.springframework.amqp.rabbit.annotation.
Queue
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
Argument
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
QueueBinding
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
EnableRabbit
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
RabbitHandler
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
RabbitListener
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
RabbitListeners
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.annotation.
Exchange
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.junit.
LongRunning
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.junit.
RabbitAvailable
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.junit.
LogLevels
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.test.context.
SpringRabbitTest
(implements java.lang.annotation.
Annotation
)
org.springframework.amqp.rabbit.test.
RabbitListenerTest
(implements java.lang.annotation.
Annotation
)
Enum Hierarchy
java.lang.
Object
java.lang.
Enum
<E> (implements java.lang.
Comparable
<T>, java.io.
Serializable
)
org.springframework.amqp.support.converter.
Jackson2JavaTypeMapper.TypePrecedence
org.springframework.amqp.core.
AcknowledgeMode
org.springframework.amqp.core.
QueueBuilder.Overflow
org.springframework.amqp.core.
QueueBuilder.MasterLocator
org.springframework.amqp.core.
QueueBuilder.LeaderLocator
org.springframework.amqp.core.
Binding.DestinationType
org.springframework.amqp.core.
MessageDeliveryMode
org.springframework.amqp.rabbit.config.
ListenerContainerFactoryBean.Type
org.springframework.amqp.rabbit.connection.
CachingConnectionFactory.CacheMode
org.springframework.amqp.rabbit.connection.
CachingConnectionFactory.ConfirmType
org.springframework.amqp.rabbit.connection.
AbstractConnectionFactory.AddressShuffleMode
org.springframework.amqp.rabbit.test.context.
SpringRabbitTest.ContainerType
Skip navigation links
Overview
Package
Class
Tree
Deprecated
Index
Help
Spring AMQP
Prev
Next
Frames
No Frames
All Classes