Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
D
- deactivate() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
- deadLetterExchange(String) - Method in class org.springframework.amqp.core.QueueBuilder
- 
Set the dead-letter exchange to which to route expired or rejected messages.
- deadLetterRoutingKey(String) - Method in class org.springframework.amqp.core.QueueBuilder
- 
Set the routing key to use when routing expired or rejected messages to the dead-letter exchange.
- debatch(Message) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- deBatch(Message, Consumer<Message>) - Method in interface org.springframework.amqp.rabbit.batch.BatchingStrategy
- 
Decode a message into fragments.
- deBatch(Message, Consumer<Message>) - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
- 
Debatch a message that has a header withMessageProperties.SPRING_BATCH_FORMATset toMessageProperties.BATCH_FORMAT_LENGTH_HEADER4.
- Declarable - Interface in org.springframework.amqp.core
- 
Classes implementing this interface can be auto-declared with the broker during context initialization by anAmqpAdmin.
- DeclarableCustomizer - Interface in org.springframework.amqp.core
- 
Beans of this type are invoked by theAmqpAdminbefore declaring theDeclarable, allowing customization thereof.
- Declarables - Class in org.springframework.amqp.core
- 
A collection ofDeclarableobjects; used to declare multiple objects on the broker using a single bean declaration for the collection.
- Declarables(Collection<? extends Declarable>) - Constructor for class org.springframework.amqp.core.Declarables
- Declarables(Declarable...) - Constructor for class org.springframework.amqp.core.Declarables
- DeclarationExceptionEvent - Class in org.springframework.amqp.rabbit.core
- 
Application event published when a declaration exception occurs.
- DeclarationExceptionEvent(Object, Declarable, Throwable) - Constructor for class org.springframework.amqp.rabbit.core.DeclarationExceptionEvent
- declare() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
- declare() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Queue
- declare() - Element in annotation interface org.springframework.amqp.rabbit.annotation.QueueBinding
- DECLARE_METHOD_ID_10 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
AMQP declare method.
- 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
- DeclareExchangeConnectionListener - Class in org.springframework.amqp.rabbit.core
- 
AConnectionListenerthat will declare a single exchange when the connection is established.
- DeclareExchangeConnectionListener(Exchange, RabbitAdmin) - Constructor for class org.springframework.amqp.rabbit.core.DeclareExchangeConnectionListener
- declareQueue() - Method in interface org.springframework.amqp.core.AmqpAdmin
- 
Declare a queue whose name is automatically named.
- declareQueue() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- 
Declares a server-named exclusive, autodelete, non-durable queue.
- declareQueue(Queue) - Method in interface org.springframework.amqp.core.AmqpAdmin
- 
Declare the given queue.
- declareQueue(Queue) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- 
Declare the given queue.
- 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.Base64UrlNamingStrategy
- 
The default instance - usingspring.gen-as the prefix.
- DEFAULT - Static variable in class org.springframework.amqp.core.DirectExchange
- 
The default exchange.
- DEFAULT - Static variable in class org.springframework.amqp.core.UUIDNamingStrategy
- 
The default instance.
- DEFAULT_CHARSET - Static variable in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- 
The charset used when convertingStringto/frombyte[].
- 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_CONTENT_TYPE - Static variable in class org.springframework.amqp.core.MessageProperties
- DEFAULT_DEBATCHING_ENABLED - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- DEFAULT_DELIVERY_MODE - Static variable in class org.springframework.amqp.core.MessageProperties
- DEFAULT_EXCHANGE_NAME - Static variable in class org.springframework.amqp.rabbit.core.RabbitAdmin
- 
The default exchange name.
- DEFAULT_FRAME_MAX_HEADROOM - Static variable in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
- 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.junit.BrokerTestUtils
- DEFAULT_PREFETCH_COUNT - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- DEFAULT_PRIORITY - Static variable in class org.springframework.amqp.core.MessageProperties
- DEFAULT_QUEUE_NAME - Static variable in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- DEFAULT_RABBIT_LISTENER_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
- 
The bean name of the defaultRabbitListenerContainerFactory.
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- 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.AbstractMessageListenerContainer
- 
The default recovery interval: 5000 ms = 5 seconds.
- DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- DefaultClassMapper - Class in org.springframework.amqp.support.converter
- 
Maps to/from JSON using type information in theMessageProperties; the default name of the message property containing the type is "__TypeId__".
- DefaultClassMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultClassMapper
- DefaultExceptionStrategy() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
- DefaultJackson2JavaTypeMapper - Class in org.springframework.amqp.support.converter
- 
Jackson 2 type mapper.
- DefaultJackson2JavaTypeMapper() - Constructor for class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
- DefaultMessagePropertiesConverter - Class in org.springframework.amqp.rabbit.support
- 
Default implementation of theMessagePropertiesConverterstrategy.
- DefaultMessagePropertiesConverter() - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
- 
Construct an instance whereLongStrings will be returned unconverted when longer than 1024 bytes.
- DefaultMessagePropertiesConverter(int) - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
- 
Construct an instance whereLongStrings will be returned unconverted when longer than this limit.
- DefaultMessagePropertiesConverter(int, boolean) - Constructor for class org.springframework.amqp.rabbit.support.DefaultMessagePropertiesConverter
- 
Construct an instance whereLongStrings will be returned unconverted or as aDataInputStreamwhen longer than this limit.
- DefaultRabbitListenerObservationConvention() - Constructor for class org.springframework.amqp.rabbit.support.micrometer.RabbitListenerObservation.DefaultRabbitListenerObservationConvention
- DefaultRabbitListenerObservationConvention() - Constructor for class org.springframework.rabbit.stream.micrometer.RabbitStreamMessageReceiverContext.DefaultRabbitListenerObservationConvention
- DefaultRabbitStreamListenerObservationConvention() - Constructor for class org.springframework.rabbit.stream.micrometer.RabbitStreamListenerObservation.DefaultRabbitStreamListenerObservationConvention
- DefaultRabbitStreamTemplateObservationConvention() - Constructor for class org.springframework.rabbit.stream.micrometer.RabbitStreamTemplateObservation.DefaultRabbitStreamTemplateObservationConvention
- DefaultRabbitTemplateObservationConvention() - Constructor for class org.springframework.amqp.rabbit.support.micrometer.RabbitTemplateObservation.DefaultRabbitTemplateObservationConvention
- DefaultStreamMessageConverter - Class in org.springframework.rabbit.stream.support.converter
- 
DefaultStreamMessageConverter.
- DefaultStreamMessageConverter() - Constructor for class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
- 
Construct an instance using aWrapperMessageBuilder.
- DefaultStreamMessageConverter(Codec) - Constructor for class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
- 
Construct an instance using the provided codec.
- DeflaterPostProcessor - Class in org.springframework.amqp.support.postprocessor
- 
A post processor that uses aDeflaterOutputStreamto compress the message body.
- DeflaterPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
- DeflaterPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.DeflaterPostProcessor
- DELAY - Static variable in class org.springframework.amqp.support.AmqpHeaders
- delayed() - Method in class org.springframework.amqp.core.ExchangeBuilder
- 
Set the delayed flag.
- delayed() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
- DelegatingDecompressingPostProcessor - Class in org.springframework.amqp.support.postprocessor
- 
AMessagePostProcessorthat delegates to one of itsMessagePostProcessors depending on the content encoding.
- DelegatingDecompressingPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
- 
Construct an instance with the default decompressors (gzip, zip, deflate) with the alwaysDecompress flag set to true.
- DelegatingInvocableHandler - Class in org.springframework.amqp.rabbit.listener.adapter
- 
Delegates to anInvocableHandlerMethodbased on the message payload type.
- DelegatingInvocableHandler(List<InvocableHandlerMethod>, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
- 
Construct an instance with the supplied handlers for the bean.
- DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
- 
Construct an instance with the supplied handlers for the bean.
- DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext, Validator) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
- 
Construct an instance with the supplied handlers for the bean.
- deleteExchange(String) - Method in interface org.springframework.amqp.core.AmqpAdmin
- 
Delete an exchange.
- deleteExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- deleteExchanges(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- 
Delete arbitrary exchanges from the broker.
- deleteExchanges(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- 
Delete arbitrary exchanges from the broker.
- 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) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- deleteQueue(String, boolean, boolean) - Method in interface org.springframework.amqp.core.AmqpAdmin
- 
Delete a queue.
- deleteQueue(String, boolean, boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- deleteQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- 
Delete arbitrary queues from the broker.
- deleteQueues(String...) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- 
Delete arbitrary queues from the broker.
- Delivery - Class in org.springframework.amqp.rabbit.support
- 
Encapsulates an arbitrary message - simple "bean" holder structure.
- Delivery(String, Envelope, AMQP.BasicProperties, byte[], String) - Constructor for class org.springframework.amqp.rabbit.support.Delivery
- DELIVERY_MODE - Static variable in class org.springframework.amqp.support.AmqpHeaders
- DELIVERY_TAG - Static variable in class org.springframework.amqp.support.AmqpHeaders
- deliveryLimit(int) - Method in class org.springframework.amqp.core.QueueBuilder
- 
Set the delivery limit; only applies to quorum queues.
- deserialize(byte[]) - Static method in class org.springframework.amqp.utils.SerializationUtils
- 
Deserialize the bytes.
- deserialize(InputStream, Set<String>, ClassLoader) - Static method in class org.springframework.amqp.utils.SerializationUtils
- 
Deserialize the stream.
- deserialize(ObjectInputStream) - Static method in class org.springframework.amqp.utils.SerializationUtils
- 
Deserialize the stream.
- destination - Variable in class org.springframework.amqp.core.BindingBuilder.DirectExchangeRoutingKeyConfigurer
- 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.AbstractRoutingConnectionFactory
- destroy() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- 
Close the underlying shared connection.
- destroy() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- destroy() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- destroy() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- destroy() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- destroy() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
CallsAbstractMessageListenerContainer.shutdown()when the BeanFactory destroys the container instance.
- destroy() - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- destroy() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- 
Determine the current lookup key.
- determineCurrentLookupKey() - Method in class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
- determineTargetConnectionFactory() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- 
Retrieve the current targetConnectionFactory.
- direct - Enum constant in enum class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean.Type
- direct - Enum constant in enum class org.springframework.amqp.rabbit.test.context.SpringRabbitTest.ContainerType
- DIRECT - Static variable in class org.springframework.amqp.core.ExchangeTypes
- 
Direct exchange.
- directExchange(String) - Static method in class org.springframework.amqp.core.ExchangeBuilder
- 
Return aDirectExchangebuilder.
- 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
- DirectMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
- 
TheSimpleMessageListenerContaineris not so simple.
- DirectMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- 
Create an instance;RabbitAccessor.setConnectionFactory(ConnectionFactory)must be called before starting.
- DirectMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- 
Create an instance with the provided connection factory.
- DirectRabbitListenerContainerFactory - Class in org.springframework.amqp.rabbit.config
- 
ARabbitListenerContainerFactoryimplementation to build a regularDirectMessageListenerContainer.
- DirectRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
- DirectReplyToMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
- 
Listener container for Direct ReplyTo only listens to the pseudo queueAddress.AMQ_RABBITMQ_REPLY_TO.
- DirectReplyToMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- DirectReplyToMessageListenerContainer.ChannelHolder - Class in org.springframework.amqp.rabbit.listener
- 
Holder for a channel; contains a consumer epoch used to prevent inappropriate release of the consumer after it has been allocated for reuse.
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- doCleanupAfterCompletion(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- doGetTransaction() - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- doHandleResult(InvocationResult, Message, Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- 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.DirectMessageListenerContainer
- doInitialize() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
- doInRabbit(Channel) - Method in interface org.springframework.amqp.rabbit.core.ChannelCallback
- 
Execute any number of operations against the supplied RabbitMQChannel, possibly returning a result.
- doInRabbit(RabbitOperations) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations.OperationsCallback
- 
Execute any number of operations using a dedicatedChannelas long as those operations are performed on the template argument and on the calling thread.
- doInvoke(Object...) - Method in class org.springframework.amqp.rabbit.listener.adapter.KotlinAwareInvocableHandlerMethod
- doInvokeListener(MessageListener, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Invoke the specified listener as Spring Rabbit MessageListener.
- doInvokeListener(ChannelAwareMessageListener, Channel, Object) - 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.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.amqp.rabbit.config.QueueParser
- doParseBindings(Element, ParserContext, String, Element, AbstractExchangeParser) - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
- doPublish(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- doReceive(String) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- doReceiveNoWait(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Non-blocking receive.
- doRedeclareElementsIfNecessary() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- 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, boolean, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Send the given message to the specified exchange.
- doSend(String, String, Message) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
- 
Send the message.
- doSend(String, String, Message) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
- doSend(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- doSend(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- doSend(AmqpAppender.Event, LogEvent, MessageProperties) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
- doSendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Send a message and wait for a reply.
- doSendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- doSendAndReceive(String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- doSendAndReceiveWithFixed(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- doSendAndReceiveWithFixed(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
- doSendAndReceiveWithTemporary(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- doSetPossibleAuthenticationFailureFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- doSetPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- 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.
- doStart() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
- doStart() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Perform additional start actions.
- 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.DirectMessageListenerContainer
- doStart() - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- 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.core.BatchingRabbitTemplate
- doStop() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Perform additional stop actions.
- 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.DirectMessageListenerContainer
- doSuspend(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- dropHead - Enum constant in enum class org.springframework.amqp.core.QueueBuilder.Overflow
- 
Drop the oldest message.
- durable() - Static method in class org.springframework.amqp.core.QueueBuilder
- 
Creates a builder for a durable queue with a generated unique name -spring.gen-<random>.
- durable() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
- durable() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Queue
- 
Specifies if this queue should be durable.
- durable(boolean) - Method in class org.springframework.amqp.core.ExchangeBuilder
- 
Set the durable flag.
- durable(String) - Static method in class org.springframework.amqp.core.QueueBuilder
- 
Creates a builder for a durable queue.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form