Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
C
- CachingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
- 
AConnectionFactoryimplementation that (when the cache mode isCachingConnectionFactory.CacheMode.CHANNEL(default) returns the same Connection from allCachingConnectionFactory.createConnection()calls, and ignores calls toConnection.close()and cachesChannel.
- 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(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(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- 
Create a new CachingConnectionFactory for the given target ConnectionFactory.
- CachingConnectionFactory(String) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- 
Create a new CachingConnectionFactory given a host name.
- CachingConnectionFactory(String, int) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- 
Create a new CachingConnectionFactory given a host name and port.
- CachingConnectionFactory(URI) - Constructor for class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- 
Create a new CachingConnectionFactory given aURI.
- CachingConnectionFactory.CacheMode - Enum Class in org.springframework.amqp.rabbit.connection
- 
The cache mode.
- CachingConnectionFactory.ConfirmType - Enum Class in org.springframework.amqp.rabbit.connection
- 
The type of publisher confirms to use.
- call(String, Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
- 
Execute aCallablebinding the givenConnectionFactoryand finally unbinding it.
- call(Callable<T>) - Method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
- 
Execute aCallablebinding to the defaultConnectionFactoryand finally unbinding it.
- cancel(boolean) - Method in class org.springframework.amqp.rabbit.RabbitFuture
- cancel(Channel, String) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- cancelled() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- canDebatch(MessageProperties) - Method in interface org.springframework.amqp.rabbit.batch.BatchingStrategy
- 
Return true if this strategy can decode a batch of messages from a message body.
- canDebatch(MessageProperties) - Method in class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
- capture() - Element in annotation interface org.springframework.amqp.rabbit.test.RabbitListenerTest
- 
Set to true to advise the listener with a capture advice,
- categories() - Element in annotation interface org.springframework.amqp.rabbit.junit.LogLevels
- 
Category names representing Log4j or Logback categories to change.
- categories(String...) - Method in class org.springframework.amqp.rabbit.junit.LogLevelAdjuster
- CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
- 
Key name for the logger level name in the message properties.
- CATEGORY_LEVEL - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Key name for the logger level name in the message properties
- CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
- 
Key name for the logger category name in the message properties.
- CATEGORY_NAME - Static variable in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Key name for the logger category name in the message properties
- causeChainContainsARADRE(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
- 
Return true if there is already anAmqpRejectAndDontRequeueExceptionpresent in the cause chain.
- causeChainHasImmediateAcknowledgeAmqpException(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Traverse the cause chain and, if anImmediateAcknowledgeAmqpExceptionis found before anAmqpRejectAndDontRequeueException, return true.
- CHANNEL - Enum constant in enum class org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
- 
Cache channels - single connection.
- CHANNEL - Static variable in class org.springframework.amqp.support.AmqpHeaders
- CHANNEL_PROTOCOL_CLASS_ID_20 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
AMQP Channel protocol class id.
- ChannelAwareBatchMessageListener - Interface in org.springframework.amqp.rabbit.listener.api
- 
Used to receive a batch of messages if the container supports it.
- ChannelAwareMessageListener - Interface in org.springframework.amqp.rabbit.listener.api
- 
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
- 
A listener for new channel creation and destruction.
- ChannelProxy - Interface in org.springframework.amqp.rabbit.connection
- 
Subinterface ofChannelto be implemented by Channel proxies.
- checkAfterCompletion() - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
- 
When using transaction synchronization, call this method after the transaction commits to verify that the RabbitMQ transaction committed.
- checkAllowedList(Class<?>) - Method in class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
- checkAllowedList(Class<?>, Set<String>) - Static method in class org.springframework.amqp.utils.SerializationUtils
- 
Verify that the class is in the allowed list.
- checkConnect() - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- 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.
- checkMicrometer() - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- checkMismatchedQueues() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- checkObservation() - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- checkOptional(Type) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
- classes() - Element in annotation interface org.springframework.amqp.rabbit.junit.LogLevels
- 
Classes representing Log4j categories to change.
- 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.
- clear() - Static method in class org.springframework.amqp.rabbit.connection.SimpleResourceHolder
- 
Clear resources for the current thread.
- clearConfirmListeners() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- clearConnectionListeners() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
- clearConnectionListeners() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- clearDelegates() - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
- clearDeliveryTags() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- 
Clear the delivery tags when rolling back with an external transaction manager.
- clearEnvironmentVariableOverrides() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- 
Clear any environment variable overrides set inBrokerRunning.setEnvironmentVariableOverrides(Map).
- clearEnvironmentVariableOverrides() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- 
Clear any environment variable overrides set inBrokerRunningSupport.setEnvironmentVariableOverrides(Map).
- clearPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Clear the physicalCloseRequired flag.
- clearReturnListeners() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- clientLocal - Enum constant in enum class org.springframework.amqp.core.QueueBuilder.LeaderLocator
- 
Deploy on the node we are connected to.
- clone() - Method in class org.springframework.amqp.core.Queue
- close() - Method in interface org.springframework.amqp.rabbit.connection.Connection
- 
Close this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.
- close() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- close() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
- close() - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
- close() - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- close(int, String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- close(T) - Method in interface org.springframework.amqp.rabbit.connection.NodeLocator
- 
Close the client.
- closeAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
- closeAndClear(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- closeChannel(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Close the given RabbitMQ Channel and ignore any thrown exception.
- closeChannels(Collection<ChannelProxy>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- closeConnection(Connection) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Close the given RabbitMQ Connection and ignore any thrown exception.
- closeMessageConsumer(Channel, Collection<String>, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- closeThreadChannel() - Method in interface org.springframework.amqp.rabbit.connection.Connection
- 
Close any channel associated with the current thread.
- closeThreadChannel() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- 
Close the channel associated with this thread, if any.
- ClosingRecoveryListener - Class in org.springframework.amqp.rabbit.connection
- 
ARecoveryListenerthat closes the recovered channel, to avoid orphaned consumers.
- CLUSTER_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
- commitAll() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
- commitIfNecessary(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- 
Perform a commit or message acknowledgement, as appropriate.
- commitIfNecessary(Channel) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Commit the Channel if not within a JTA transaction.
- 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
- 
A composite listener that invokes its delegages in turn.
- CompositeConnectionListener() - Constructor for class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
- CompositeContainerCustomizer<C extends MessageListenerContainer> - Class in org.springframework.amqp.rabbit.config
- 
Implementation ofContainerCustomizerproviding the configuration of multiple customizers at the same time.
- CompositeContainerCustomizer(List<ContainerCustomizer<C>>) - Constructor for class org.springframework.amqp.rabbit.config.CompositeContainerCustomizer
- 
Create an instance with the provided delegate customizers.
- concurrency() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
- 
Set the concurrency of the listener container for this listener.
- ConditionalExceptionLogger - Interface in org.springframework.amqp.support
- 
For components that support customization of the logging of certain events, users can provide an implementation of this interface to modify the existing logging behavior.
- ConditionalRejectingErrorHandler - Class in org.springframework.amqp.rabbit.listener
- 
ErrorHandlerthat conditionally wraps the Exception in anAmqpRejectAndDontRequeueExceptionif the configured rejection strategy determines that the message is fatal and should not be requeued.
- ConditionalRejectingErrorHandler() - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
- 
Create a handler with theConditionalRejectingErrorHandler.DefaultExceptionStrategy.
- ConditionalRejectingErrorHandler(FatalExceptionStrategy) - Constructor for class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
- 
Create a handler with the suppliedFatalExceptionStrategyimplementation.
- ConditionalRejectingErrorHandler.DefaultExceptionStrategy - Class in org.springframework.amqp.rabbit.listener
- 
Default implementation ofFatalExceptionStrategy.
- configure(C) - Method in class org.springframework.amqp.rabbit.config.CompositeContainerCustomizer
- configure(C) - Method in interface org.springframework.amqp.rabbit.config.ContainerCustomizer
- 
Configure the container.
- configureAdminIfNeeded() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- configureKeyManagers() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- configureListenerAdapter(MessagingMessageListenerAdapter) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
- 
Create aHandlerAdapterfor this listener adapter.
- configureListenerAdapter(MessagingMessageListenerAdapter) - Method in class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
- configureRabbitConnectionFactory(RabbitConnectionFactoryBean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
- 
Configure theRabbitConnectionFactoryBean.
- configureRabbitConnectionFactory(RabbitConnectionFactoryBean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Configure theRabbitConnectionFactoryBean.
- configureRabbitListeners(RabbitListenerEndpointRegistrar) - Method in interface org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurer
- 
Callback allowing aRabbitListenerEndpointRegistryand specificRabbitListenerEndpointinstances to be registered against the givenRabbitListenerEndpointRegistrar.
- configureTrustManagers() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- confirm(CorrelationData, boolean, String) - Method in interface org.springframework.amqp.rabbit.core.RabbitTemplate.ConfirmCallback
- 
Confirmation callback.
- Confirm(boolean, String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
- confirmSelect() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- Connection - Interface in org.springframework.amqp.rabbit.connection
- CONNECTION - Enum constant in enum class org.springframework.amqp.rabbit.connection.CachingConnectionFactory.CacheMode
- 
Cache connections and channels within each connection.
- CONNECTION_PROTOCOL_CLASS_ID_10 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
AMQP Connection protocol class id.
- ConnectionBlockedEvent - Class in org.springframework.amqp.rabbit.connection
- 
TheAmqpEventemitted by theCachingConnectionFactorywhen its connections are blocked.
- ConnectionBlockedEvent(Connection, String) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionBlockedEvent
- connectionFactory - Variable in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- ConnectionFactory - Interface in org.springframework.amqp.rabbit.connection
- 
An interface based ConnectionFactory for creatingConnections.
- ConnectionFactoryConfigurationUtils - Class in org.springframework.amqp.rabbit.connection
- 
Utility methods for configuring connection factories.
- ConnectionFactoryContextWrapper - Class in org.springframework.amqp.rabbit.connection
- 
Helper class to handleConnectionFactorycontext binding and unbinding when executing instructions.
- ConnectionFactoryContextWrapper(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionFactoryContextWrapper
- ConnectionFactoryUtils - Class in org.springframework.amqp.rabbit.connection
- 
Helper class for managing a Spring based RabbitConnectionFactory, in particular for obtaining transactional Rabbit resources for a given ConnectionFactory.
- ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.amqp.rabbit.connection
- 
Callback interface for resource creation.
- ConnectionListener - Interface in org.springframework.amqp.rabbit.connection
- 
A listener for connection creation and closing.
- ConnectionNameStrategy - Interface in org.springframework.amqp.rabbit.connection
- 
A strategy to build an application-specific connection name, which can be displayed in the management UI if RabbitMQ server supports it.
- ConnectionProxy - Interface in org.springframework.amqp.rabbit.connection
- 
Subinterface ofConnectionto be implemented by Connection proxies.
- ConnectionUnblockedEvent - Class in org.springframework.amqp.rabbit.connection
- 
TheAmqpEventemitted by theCachingConnectionFactorywhen its connections are unblocked.
- ConnectionUnblockedEvent(Connection) - Constructor for class org.springframework.amqp.rabbit.connection.ConnectionUnblockedEvent
- CONSUME_METHOD_ID_20 - Static variable in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
AMQP consume method.
- ConsumeOkEvent - Class in org.springframework.amqp.rabbit.listener
- 
AnAmqpEventemitted by the listener container when consumer is subscribed to the queue.
- ConsumeOkEvent(Object, String, String) - Constructor for class org.springframework.amqp.rabbit.listener.ConsumeOkEvent
- 
Instantiate aConsumeOkEventbased on the provided consumer, queue and consumer tag.
- ConsumeOkNotReceivedException - Exception in org.springframework.amqp.rabbit.core
- 
Thrown when a blocking receive operation is performed but the consumeOk was not received before the receive timeout.
- ConsumeOkNotReceivedException(String) - Constructor for exception org.springframework.amqp.rabbit.core.ConsumeOkNotReceivedException
- CONSUMER_QUEUE - Static variable in class org.springframework.amqp.support.AmqpHeaders
- 
The queue from which the listener container consumer received the message.
- CONSUMER_TAG - Static variable in class org.springframework.amqp.support.AmqpHeaders
- 
The tag of the listener container consumer that received the message.
- ConsumerCancelledException - Exception in org.springframework.amqp.rabbit.support
- 
Thrown when the broker cancels the consumer and the message queue is drained.
- ConsumerCancelledException() - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
- ConsumerCancelledException(Throwable) - Constructor for exception org.springframework.amqp.rabbit.support.ConsumerCancelledException
- ConsumerChannelRegistry - Class in org.springframework.amqp.rabbit.connection
- 
Consumers register their primary channels with this class.
- consumerCount(String) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- ConsumerCustomizer - Interface in org.springframework.rabbit.stream.listener
- 
Customizer forConsumerBuilder.
- consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- 
Called whenever a consumer is removed.
- consumerRemoved(DirectMessageListenerContainer.SimpleConsumer) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- consumers - Variable in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- consumersMonitor - Variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- ConsumerTagStrategy - Interface in org.springframework.amqp.support
- 
A strategy interface to determine the consumer tag to be used when issuing abasicConsumeoperation.
- containerAckMode(AcknowledgeMode) - Method in interface org.springframework.amqp.core.MessageListener
- 
Called by the container to inform the listener of its acknowledgement mode.
- containerAckMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- ContainerCustomizer<C extends MessageListenerContainer> - Interface in org.springframework.amqp.rabbit.config
- 
Called by the container factory after the container is created and configured.
- containerFactory() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
- 
The bean name of theRabbitListenerContainerFactoryto use to create the message listener container responsible to serve this endpoint.
- containerType() - Element in annotation interface org.springframework.amqp.rabbit.test.context.SpringRabbitTest
- 
Set the container type to determine which container factory to configure.
- ContainerUtils - Class in org.springframework.amqp.rabbit.listener.support
- 
Utility methods for listener containers.
- containsChannel(Channel) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
- CONTENT_ENCODING - Static variable in class org.springframework.amqp.support.AmqpHeaders
- CONTENT_LENGTH - Static variable in class org.springframework.amqp.support.AmqpHeaders
- CONTENT_TYPE - Static variable in class org.springframework.amqp.support.AmqpHeaders
- CONTENT_TYPE_BYTES - Static variable in class org.springframework.amqp.core.MessageProperties
- CONTENT_TYPE_CONVERTER_WINS - Static variable in class org.springframework.amqp.support.AmqpHeaders
- CONTENT_TYPE_JSON - Static variable in class org.springframework.amqp.core.MessageProperties
- CONTENT_TYPE_JSON_ALT - 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
- ContentTypeDelegatingMessageConverter - Class in org.springframework.amqp.support.converter
- 
A compositeMessageConverterthat delegates to an actualMessageConverterbased on the contentType header.
- ContentTypeDelegatingMessageConverter() - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
- 
Constructs an instance using a defaultSimpleMessageConverter.
- ContentTypeDelegatingMessageConverter(MessageConverter) - Constructor for class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
- 
Constructs an instance using a the supplied default converter.
- ContinuationHandlerMethodArgumentResolver - Class in org.springframework.amqp.rabbit.listener.adapter
- 
No-op resolver for method arguments of typeContinuation.
- ContinuationHandlerMethodArgumentResolver() - Constructor for class org.springframework.amqp.rabbit.listener.adapter.ContinuationHandlerMethodArgumentResolver
- convert(Object, Type, MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- 
Convert to a message, with reply content type based on settings.
- convert(Message, Type) - Method in class org.springframework.amqp.support.converter.ProjectingMessageConverter
- convertAmqpException(RuntimeException) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertAmqpMessage(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertAndSend(Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.
- convertAndSend(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(Object) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
- 
Convert to and send a Spring AMQP message.
- convertAndSend(Object) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.
- convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
- 
Convert to and send a Spring AMQP message.
- convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- convertAndSend(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.
- convertAndSend(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.
- convertAndSend(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.
- convertAndSend(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.
- convertAndSend(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.
- convertAndSend(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given Object to serialized form, possibly using aMessageConverter, wrap it as a message and send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertAndSend(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, String, Object, Map<String, Object>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given Object to serialized form, possibly using aMessageConverter, wrap it as a message with the given headers and send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, Map<String, Object>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given Object to serialized form, possibly using aMessageConverter, wrap it as a message with the given headers, apply the given post processor, and send the resulting message to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, Map<String, Object>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given Object to serialized form, possibly using aMessageConverter, wrap it as a message, apply the given post processor, and send the resulting message to a specific exchange with a specific routing key.
- convertAndSend(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- converterWinsContentType() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
- 
Set to 'false' to override any content type headers set by the message converter with the value of the 'replyContentType' property.
- convertMessageIfNecessary(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertRabbitAccessException(Exception) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
- convertRabbitAccessException(Throwable) - Static method in class org.springframework.amqp.rabbit.support.RabbitExceptionTranslator
- convertSendAndReceive(Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the default routing key.
- convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the default routing key after invoking theMessagePostProcessor.
- convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the provided routing key.
- convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, 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.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the provided routing key after invoking theMessagePostProcessor.
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, 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.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the provided exchange and routing key.
- convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(String, String, Object) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, String, Object, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given request Object to serialized form, possibly using aMessageConverter, send it as aMessageto a specific exchange with a specific routing key, receive the reply and convert its body of the specified target class.
- convertSendAndReceive(String, String, Object, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given request Object to serialized form, possibly using aMessageConverter, apply the given post processor and send the resultingMessageto a specific exchange with a specific routing key, receive the reply and convert its body of the given target class.
- convertSendAndReceive(String, String, Object, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given request Object to serialized form, possibly using aMessageConverter, send it as aMessagewith the given headers, to a specific exchange with a specific routing key, receive the reply and convert its body of the specified target class.
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
- 
Convert the given request Object to serialized form, possibly using aMessageConverter, wrap it as a message with the given headers, apply the given post processor and send the resultingMessageto a specific exchange with a specific routing key,, receive the reply and convert its body of the given target class.
- convertSendAndReceive(String, String, Object, Map<String, Object>, Class<T>, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- convertSendAndReceive(String, 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.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the provided exchange and routing key after invoking theMessagePostProcessor.
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceive(String, String, Object, MessagePostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceive(String, String, Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceive(String, String, Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the default routing key after invoking theMessagePostProcessor.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the default routing key.
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the provided routing key after invoking theMessagePostProcessor.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the default exchange with the provided routing key.
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, CorrelationData, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the provided exchange and routing key after invoking theMessagePostProcessor.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, MessagePostProcessor, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveAsType(String, String, Object, CorrelationData, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
- 
Convert the object to a message and send it to the provided exchange and routing key.
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in interface org.springframework.amqp.core.AmqpTemplate
- 
Basic RPC pattern with conversion.
- convertSendAndReceiveAsType(String, String, Object, ParameterizedTypeReference<T>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- convertSendAndReceiveRaw(String, String, Object, MessagePostProcessor, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Convert and send a message and return the raw reply message, or null.
- copyHeaders(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- copyHeadersIfAbsent(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- copyProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessagePropertiesBuilder
- CORRELATED - Enum constant in enum class org.springframework.amqp.rabbit.connection.CachingConnectionFactory.ConfirmType
- 
Use withCorrelationDatato correlate confirmations with sent messsages.
- Correlation - Interface in org.springframework.amqp.core
- 
A marker interface for data used to correlate information about sent messages.
- CORRELATION_ID - Static variable in class org.springframework.amqp.support.AmqpHeaders
- correlationConvertAndSend(Object, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.
- correlationConvertAndSend(Object, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- CorrelationData - Class in org.springframework.amqp.rabbit.connection
- 
Base class for correlating publisher confirms to sent messages.
- CorrelationData() - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
- 
Construct an instance with a null Id.
- CorrelationData(String) - Constructor for class org.springframework.amqp.rabbit.connection.CorrelationData
- 
Construct an instance with the supplied id.
- CorrelationData.Confirm - Class in org.springframework.amqp.rabbit.connection
- 
Represents a publisher confirmation.
- CorrelationDataPostProcessor - Interface in org.springframework.amqp.rabbit.core
- 
A callback invoked immediately before publishing a message to update, replace, or create correlation data for publisher confirms.
- countDown() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
- 
Count down the returned message latch; call after the listener has been called.
- counter - Variable in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- 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(boolean) - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
- createChannel(Channel, ExecutorService) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannelFactory
- 
Create aPublisherCallbackChannelinstance based on the provided delegate and executor.
- createChannel(Connection) - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
- 
Create a new RabbitMQ Session for registration with a RabbitResourceHolder.
- createClient(String, String) - Method in interface org.springframework.amqp.rabbit.connection.NodeLocator
- 
Create a client for subsequent use.
- createClient(String, String) - Method in class org.springframework.amqp.rabbit.connection.RestTemplateNodeLocator
- createClient(String, String) - Method in class org.springframework.amqp.rabbit.connection.WebFluxNodeLocator
- 
Create a client instance.
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
- createConnection() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
- 
Create a new RabbitMQ Connection for registration with a RabbitResourceHolder.
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- createConnection() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- 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 class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- createConnection(ConnectionFactory, boolean) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
- 
Create a connection with this connection factory and/or its publisher factory.
- createConnectionFactory(String, String) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- 
Create a dedicated connection factory for the address.
- createConsumerTag(String) - Method in interface org.springframework.amqp.support.ConsumerTagStrategy
- 
Create the consumer tag, optionally based on the queue name that the consumer will listen to.
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- 
Create an empty container instance.
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
- createContainerInstance() - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- createContainerInstance() - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
- 
Create an instance of the listener container.
- 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.
- createEventQueue() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Subclasses can override this method to inject a custom queue implementation.
- createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
- createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
- createInstance() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- createInstance() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- createInstance() - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
- createInvocableHandlerMethod(Object, Method) - Method in class org.springframework.amqp.rabbit.listener.adapter.AmqpMessageHandlerMethodFactory
- createListenerContainer() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
- 
Create aMessageListenerContainerwith noMessageListeneror queues; the listener must be added later before the container is started.
- createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
- createListenerContainer(RabbitListenerEndpoint) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerContainerFactory
- 
Create aMessageListenerContainerfor the givenRabbitListenerEndpoint.
- createListenerContainer(RabbitListenerEndpoint) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
- createListenerContainer(RabbitListenerEndpoint, RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- 
Create and start a newMessageListenerContainerusing the specified factory.
- createMessage(Object, MessageProperties) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- 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.MarshallingMessageConverter
- 
Marshals the given object to aMessage.
- 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.
- createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- createMessage(Object, MessageProperties, Type) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
- 
Crate a message from the payload object and message properties provided.
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- 
Create aMessageListenerthat is able to serve this endpoint for the specified container.
- createMessageListener(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
- createMessageListenerInstance(Boolean) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
- 
Create an emptyMessagingMessageListenerAdapterinstance.
- createObjectInputStream(InputStream) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
- 
Create an ObjectInputStream for the given InputStream and codebase.
- createRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
- 
Create theConnectionFactory.
- createRabbitConnectionFactory() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Create theConnectionFactory.
- createRabbitTemplate(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
- 
Create a RabbitTemplate for the given ConnectionFactory.
- createRecoverer() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
- createRecoverer() - Method in class org.springframework.rabbit.stream.retry.StreamRetryOperationsInterceptorFactoryBean
- createSSLContext() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- 
Override this method to create and/or configure theSSLContextused by theConnectionFactory.
- 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
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form