Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
S
- selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerConfigurationSelector
- selectImports(AnnotationMetadata) - Method in class org.springframework.amqp.rabbit.test.RabbitListenerTestSelector
- send(Message) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
-
Send a native stream message.
- send(Message) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- send(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a specific exchange with a specific routing key.
- send(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
- send(String, String, Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Send a message to a specific exchange with a specific routing key.
- send(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- send(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Send a message to a specific exchange with a specific routing key.
- send(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- send(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a default exchange with a specific routing key.
- send(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- send(String, Message, CorrelationData) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
-
Send a message to the default exchange with a specific routing key.
- send(String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- send(Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Send a message to a default exchange with a default routing key.
- send(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- send(Message) - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
-
Send a Spring AMQP message.
- send(Message) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(String, String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the supplied exchange and routing key.
- sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- sendAndReceive(String, String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendAndReceive(String, String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendAndReceive(String, String, Message<?>) - Method in interface org.springframework.amqp.rabbit.core.RabbitMessageOperations
-
Send a request message to a specific exchange with a specific routing key and wait for the reply.
- sendAndReceive(String, String, Message<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(String, Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the default exchange with the supplied routing key.
- sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- sendAndReceive(String, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendAndReceive(String, Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendAndReceive(Message) - Method in interface org.springframework.amqp.core.AmqpTemplate
-
Basic RPC pattern.
- sendAndReceive(Message) - Method in interface org.springframework.amqp.core.AsyncAmqpTemplate
-
Send a message to the default exchange with the default routing key.
- sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- sendAndReceive(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendAndReceive(Message, CorrelationData) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendEvent(AmqpAppender.Event, Map<?, ?>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
- sendResponse(Channel, Address, Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Send the given response message to the given destination.
- SendRetryContextAccessor - Class in org.springframework.amqp.support
-
Type safe accessor for retried message sending.
- sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- sendToRabbit(Channel, String, String, boolean, Message) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
- SerializationUtils - Class in org.springframework.amqp.utils
-
Static utility to help with serialization.
- serialize(Object) - Static method in class org.springframework.amqp.utils.SerializationUtils
-
Serialize the object provided.
- SerializerMessageConverter - Class in org.springframework.amqp.support.converter
-
Implementation of
MessageConverter
that can work with Strings or native objects of any kind via theSerializer
andDeserializer
abstractions in Spring. - SerializerMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SerializerMessageConverter
- setAbbreviation(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setAckMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Flag controlling the behaviour of the container with respect to message acknowledgement.
- setAckTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
An approximate timeout; when
messagesPerAck
is greater than 1, and this time elapses since the last ack, the pending acks will be sent either when the next message arrives, or a short time later if no additional messages arrive. - setAckTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
An approximate timeout; when
messagesPerAck
is greater than 1, and this time elapses since the last ack, the pending acks will be sent either when the next message arrives, or a short time later if no additional messages arrive. - setActualName(String) - Method in class org.springframework.amqp.core.Queue
-
Set the name from the DeclareOk.
- setAdapterProvider(MethodRabbitListenerEndpoint.AdapterProvider) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set a provider to create adapter instances.
- setAddMdcAsHeaders(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setAddMdcAsHeaders(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set addresses for clustering.
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setAddresses(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setAddressResolver(AddressResolver) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set an
AddressResolver
to use when creating connections; overridesAbstractConnectionFactory.setAddresses(String)
,AbstractConnectionFactory.setHost(String)
, andAbstractConnectionFactory.setPort(int)
. - setAddressShuffleMode(AbstractConnectionFactory.AddressShuffleMode) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set the mode for shuffling addresses.
- setAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the
AmqpAdmin
instance to use. - setAdminPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the password for the management REST API connection default "guest".
- setAdminPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set the password for the management REST API connection default "guest".
- setAdminsThatShouldDeclare(Object...) - Method in class org.springframework.amqp.core.AbstractDeclarable
- setAdminsThatShouldDeclare(Object...) - Method in interface org.springframework.amqp.core.Declarable
-
The
AmqpAdmin
s that should declare this object; default is all admins. - setAdminsThatShouldDeclare(AmqpAdmin...) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setAdminUri(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the uri for the REST API.
- setAdminUri(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set the uri for the REST API.
- setAdminUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the user for the management REST API connection default "guest".
- setAdminUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set the user for the management REST API connection default "guest".
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setAdviceChain(Advice...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Public setter for the
Advice
to apply to listener executions. - setAdviceChain(Advice...) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Set an advice chain to apply to the listener.
- setAfterAckCallback(Consumer<Channel>) - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel
-
Set a callback to be invoked after the ack/nack has been handled.
- setAfterAckCallback(Consumer<Channel>) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set post processors which will be applied after the Message is received.
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set a
MessagePostProcessor
that will be invoked immediately after aChannel#basicGet()
and before any message conversion is performed. - setAfterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set
MessagePostProcessor
s that will be applied after message reception, before invoking theMessageListener
. - setAllowedListPatterns(List<String>) - Method in class org.springframework.amqp.support.converter.AllowedListDeserializingMessageConverter
-
Set simple patterns for allowable packages/classes for deserialization.
- setAlwaysConvertToInferredType(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
When false (default), fall back to type id headers if the type (or contents of a container type) is abstract.
- setAlwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to always requeue on transaction rollback with an external
TransactionManager
. - setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the
AmqpAdmin
, used to declare any auto-delete queues, bindings etc. - setAmqpMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
- setAppId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setAppId(String) - Method in class org.springframework.amqp.core.MessageProperties
- setAppIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- setApplicationContext(ApplicationContext) - Method in class org.springframework.amqp.rabbit.test.TestRabbitTemplate
- setApplicationContext(ApplicationContext) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- setApplicationId(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setApplicationId(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setAssumeSupportedContentType(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
By default the supported content type is assumed when there is no contentType property or it is set to the default ('application/octet-stream').
- setAsync(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setAutoDeclare(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to automatically declare elements (queues, exchanges, bindings) in the application context during container start().
- setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setAutoDelete(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setAutomaticRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set to true to enable amqp-client automatic recovery.
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- setAutoStartup(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set whether to automatically start the container after initialization.
- setAutoStartup(boolean) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
-
Set auto startup.
- setAutoStartup(boolean) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- setAutoStartup(boolean) - Method in class org.springframework.rabbit.stream.support.StreamAdmin
-
Set to false to prevent automatic startup.
- setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setAutoStartup(Boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Override the default autoStartup property.
- setBackOffExecution(BackOffExecution) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the
BackOffExecution
to use for the recovery in theSimpleMessageListenerContainer
. - setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set a
BatchingStrategy
to use when debatching messages. - setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a batching strategy to use when de-batching messages.
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setBatchingStrategy(BatchingStrategy) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
Set a
BatchingStrategy
to use when debatching messages. - setBatchListener(boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set to true to receive a list of debatched messages that were created by a
BatchingRabbitTemplate
. - setBatchListener(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set to true if this endpoint should create a batch listener.
- setBatchListener(boolean) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
Called by the container factory with the factory's batchListener property.
- setBatchReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
The number of milliseconds of timeout for gathering batch messages.
- setBatchReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The number of milliseconds of timeout for gathering batch messages.
- setBatchReceiveTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
The number of milliseconds of timeout for gathering batch messages.
- setBatchSize(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
This property has several functions.
- setBatchSize(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
This property has several functions.
- setBatchSize(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setBean(Object) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the object instance that should manage this endpoint.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Making a
BeanFactory
available is optional; if not set,RabbitListenerConfigurer
beans won't get autodetected and anendpoint registry
has to be explicitly configured. - setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setBeanFactory(BeanFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
A
BeanFactory
only needs to be available in conjunction withRabbitListenerEndpointRegistrar.setContainerFactoryBeanName(java.lang.String)
. - setBeanName(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- setBeanName(String) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- setBeanResolver(BeanResolver) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a bean resolver for runtime SpEL expressions.
- setBeforePublishPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set
MessagePostProcessor
s that will be invoked immediately before invokingChannel#basicPublish()
, after all other processing, except creating theAMQP.BasicProperties
fromMessageProperties
. - setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Set post processors that will be applied before sending replies; added to each message listener adapter.
- setBeforeSendReplyPostProcessors(MessagePostProcessor...) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set post processors that will be applied before sending replies.
- setBlockingQueueFactory(BlockingQueueFactory<AmqpAppender.Event>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setBufferSize(int) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setBuilderSupplier(Supplier<MessageBuilder>) - Method in class org.springframework.rabbit.stream.support.converter.DefaultStreamMessageConverter
-
Set a supplier for a message builder.
- setCacheMode(CachingConnectionFactory.CacheMode) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- setCause(String) - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
When the confirmation is nacked, set the cause when available.
- setChannelCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
The number of channels to maintain in the cache.
- setChannelCheckoutTimeout(long) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Sets the channel checkout timeout.
- setChannelListeners(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setChannelRpcTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setChannelTransacted(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Flag to indicate that channels created by this component will be transactional.
- setChannelTransacted(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setCharset(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setCharset(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setCharset(Charset) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Set a charset for byte[] to String method argument conversion.
- setClassMapper(ClassMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setClientConnectionProperties(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set additional client connection properties to be added to the rabbit connection, with the form
key:value[,key:value]...
. - setClientProperties(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Add custom client properties.
- setCloseExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set the strategy for logging close exceptions; by default, if a channel is closed due to a failed passive queue declaration, it is logged at debug level.
- setCloseTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
How long to wait (milliseconds) for a response to a connection close operation from the broker; default 30000 (30 seconds).
- setClusterId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setClusterId(String) - Method in class org.springframework.amqp.core.MessageProperties
- setClusterIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the concurrency of this endpoint; usually overrides any concurrency settings on the container factory.
- setConcurrency(String) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Specify concurrency limits via a "lower-upper" String, e.g.
- setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Specify the number of concurrent consumers to create.
- setConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setConfiguration(Configuration) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setConfirmCallback(RabbitTemplate.ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setConfirmTimeout(long) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecovererWithConfirms
-
Set the
confirm
timeout; default 10 seconds. - setConnectionCacheSize(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- setConnectionCreatingBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set the backoff strategy for creating connections.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
-
Set the ConnectionFactory to use for obtaining RabbitMQ
Connections
. - setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
Set the Rabbit connection factory to be used by the gateway.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- setConnectionLimit(int) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Set the connection limit when using cache mode CONNECTION.
- setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setConnectionListeners(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- setConnectionName(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setConnectionName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set a name for the connection which will appear on the RabbitMQ Admin UI.
- setConnectionNameStrategy(ConnectionNameStrategy) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Provide a
ConnectionNameStrategy
to build the name for the target RabbitMQ connection. - setConnectionThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set the
ThreadFactory
on the underlying rabbit connection factory. - setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setConnectionTimeout(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConsecutiveActiveTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If
SimpleMessageListenerContainer.maxConcurrentConsumers
is greater thenSimpleMessageListenerContainer.concurrentConsumers
, andSimpleMessageListenerContainer.maxConcurrentConsumers
has not been reached, specifies the number of consecutive cycles when a single consumer was active, in order to consider starting a new consumer. - setConsecutiveActiveTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConsecutiveIdleTrigger(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If
SimpleMessageListenerContainer.maxConcurrentConsumers
is greater thenSimpleMessageListenerContainer.concurrentConsumers
, and the number of consumers exceedsSimpleMessageListenerContainer.concurrentConsumers
, specifies the number of consecutive receive attempts that return no data; after which we consider stopping a consumer. - setConsecutiveIdleTrigger(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setConsistentConfirmsReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify whether to apply a validation enforcing all
ConnectionFactory.isPublisherConfirms()
andConnectionFactory.isPublisherReturns()
have a consistent value. - setConsumeDelay(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the consumeDelay - a time to wait before consuming in ms.
- setConsumeDelay(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the consumeDelay - a time to wait before consuming in ms.
- setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConsumerArguments(Map<String, Object>) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set consumer arguments.
- setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Set to true to present a list of messages based on the
ListenerContainerFactoryBean.setBatchSize(int)
, if the container and listener support it. - setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
Set to true to present a list of messages based on the
SimpleRabbitListenerContainerFactory.setBatchSize(Integer)
, if the listener supports it. - setConsumerBatchEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set to true to present a list of messages based on the
SimpleMessageListenerContainer.setBatchSize(int)
, if the listener supports it. - setConsumerCustomizer(ConsumerCustomizer) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
-
Customize the consumer builder before it is built.
- setConsumerCustomizer(ConsumerCustomizer) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Customize the consumer builder before it is built.
- setConsumerQueue(String) - Method in class org.springframework.amqp.core.MessageProperties
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Each queue runs in its own consumer; set this property to create multiple consumers for each queue.
- setConsumersPerQueue(int) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- setConsumersPerQueue(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Each queue runs in its own consumer; set this property to create multiple consumers for each queue.
- setConsumerStartTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
When starting a consumer, if this time (ms) elapses before the consumer starts, an error log is written; one possible cause would be if the
taskExecutor
has insufficient threads to support the container concurrency. - setConsumerTag(String) - Method in class org.springframework.amqp.core.MessageProperties
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setConsumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the implementation of
ConsumerTagStrategy
to generate consumer tags. - setContainerCustomizer(ContainerCustomizer<C>) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set a
ContainerCustomizer
that is invoked after a container is created and configured to enable further customization of the container. - setContainerCustomizer(ContainerCustomizer<StreamListenerContainer>) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
-
Set a
ContainerCustomizer
that is invoked after a container is created and configured to enable further customization of the container. - setContainerFactory(RabbitListenerContainerFactory<?>) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the
RabbitListenerContainerFactory
to use in case aRabbitListenerEndpoint
is registered with anull
container factory. - setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Set the name of the
RabbitListenerContainerFactory
to use by default. - setContainerFactoryBeanName(String) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the bean name of the
RabbitListenerContainerFactory
to use in case aRabbitListenerEndpoint
is registered with anull
container factory. - setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setContentEncoding(String) - Method in class org.springframework.amqp.core.MessageProperties
- setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setContentEncoding(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setContentEncodingIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setContentLength(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setContentLength(long) - Method in class org.springframework.amqp.core.MessageProperties
- setContentLengthIfAbsent(long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setContentType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setContentType(String) - Method in class org.springframework.amqp.core.MessageProperties
- setContentType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setContentType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setContentType(String) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the contentType to be used by this message converter.
- setContentTypeIfAbsentOrDefault(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setConverterWinsContentType(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set whether the content type set by a converter prevails or not.
- setConverterWinsContentType(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set whether the content type set by a converter prevails or not.
- setCopyProperties(boolean) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Flag to indicate if
MessageProperties
should be used as is or cloned for new message after compression. - setCorrelationDataPostProcessor(CorrelationDataPostProcessor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set a
CorrelationDataPostProcessor
to be invoked before publishing a message. - setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setCorrelationId(String) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the correlation id.
- setCorrelationIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setCorrelationKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
If set to 'correlationId' (default) the correlationId property will be used; otherwise the supplied key will be used.
- setCreateMessageIds(boolean) - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
-
Flag to indicate that new messages should have unique identifiers added to their properties before sending.
- setCreationTime(long) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.creationTime(long)
. - setCredentialsProvider(CredentialsProvider) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a credentials provider (e.g.
- setCredentialsRefreshService(CredentialsRefreshService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a refresh service.
- setCustomMethodArgumentResolvers(HandlerMethodArgumentResolver...) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Add custom methods arguments resolvers to
RabbitListenerAnnotationBeanPostProcessor
Default empty list. - setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setDeBatchingEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Determine whether the container should de-batch batched messages (true) or call the listener with the batch (false).
- setDeBatchingEnabled(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Determine whether or not the container should de-batch batched messages (true) or call the listener with the batch (false).
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the number of retries after passive queue declaration fails.
- setDeclarationRetries(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set the number of retries after passive queue declaration fails.
- setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setDeclareExchange(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setDecompressors(Map<String, MessagePostProcessor>) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
Replace all the decompressors.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Specify the default charset to use when converting to or from text-based Message body content.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
Specify the default charset to use when converting to or from text-based Message body content.
- setDefaultCharset(String) - Method in class org.springframework.amqp.support.converter.SimpleMessageConverter
-
Specify the default charset to use when converting to or from text-based Message body content.
- setDefaultConsumer(Consumer) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- setDefaultEncoding(String) - Static method in class org.springframework.amqp.core.Message
-
Set the encoding to use in
Message.toString()
when converting the body if there is nocontentEncoding
message property present. - setDefaultListenerMethod(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Specify the name of the default listener method to delegate to, for the case where no specific listener method has been determined.
- setDefaultMapClass(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Set the type of
Map
to use. - setDefaultReceiveQueue(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default queue to receive messages from when none is specified explicitly.
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the default behavior when a message is rejected, for example because the listener threw an exception.
- setDefaultRequeueRejected(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set to the value of this listener's container equivalent property.
- setDefaultRequeueRejected(Boolean) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
- setDefaultTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify the default target
ConnectionFactory
, if any. - setDefaultType(Class<?>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
The type returned by
DefaultClassMapper.toClass(MessageProperties)
if no type information is found in the message properties. - setDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setDelayed(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
-
Set the delayed flag.
- setDelayLong(Long) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the x-delay header to a long value.
- setDelegate(Object) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set a target object to delegate message listening to.
- setDelegates(List<? extends ChannelListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeChannelListener
- setDelegates(List<? extends ConnectionListener>) - Method in class org.springframework.amqp.rabbit.connection.CompositeConnectionListener
- setDelegates(Map<String, MessageConverter>) - Method in class org.springframework.amqp.support.converter.ContentTypeDelegatingMessageConverter
- setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setDeliveryMode(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
- setDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
-
Specify a
MessageDeliveryMode
to set into the message to republish if the message doesn't have it already. - setDeliveryModeIfAbsentOrDefault(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setDeliveryTag(long) - Method in class org.springframework.amqp.core.MessageProperties
- setDeliveryTag(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setDeliveryTagIfAbsent(Long) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setDeserializer(Deserializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
The deserializer to use for converting from message body to Java object.
- setDestinationExchange(Exchange) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setDestinationQueue(Queue) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setDiscardFatalsWithXDeath(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
Set to false to disable the (now) default behavior of logging and discarding messages that cause fatal exceptions and have an `x-death` header; which usually means that the message has been republished after previously being sent to a DLQ.
- setDMLCCustomizer(ContainerCustomizer<DirectMessageListenerContainer>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Set a
ContainerCustomizer
that is invoked after a container is created and configured to enable further customization of the container. - setDurable(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setDurable(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setEnableConfirms(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set to true to enable publisher confirms.
- setEnableHostnameVerification(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Enable server hostname verification for TLS connections.
- setEncoder(Encoder<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The encoding to use when converting between byte arrays and Strings in message properties.
- setEncoding(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
The encoding to use when inter-converting between byte arrays and Strings in message properties.
- setEncodingDelimiter(String) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Set a delimiter to be added between the compression type and the original encoding, if any.
- setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Set the
RabbitListenerEndpointRegistry
that will hold the created endpoint and manage the lifecycle of the related listener container. - setEndpointRegistry(RabbitListenerEndpointRegistry) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the
RabbitListenerEndpointRegistry
instance to use. - setEnforceImmediateAckForManual(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set to
true
to enforceChannel.basicAck(long, boolean)
forAcknowledgeMode.MANUAL
whenImmediateAcknowledgeAmqpException
is thrown. - setEnforceImmediateAckForManual(Boolean) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
-
Set to
true
to enforceChannel.basicAck(long, boolean)
forAcknowledgeMode.MANUAL
whenImmediateAcknowledgeAmqpException
is thrown. - setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.annotation.MultiRabbitBootstrapConfiguration
- setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
- setEnvironment(Environment) - Method in class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
- setEnvironmentVariableOverrides(Map<String, String>) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set environment variable overrides for host, port etc.
- setEnvironmentVariableOverrides(Map<String, String>) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set environment variable overrides for host, port etc.
- setErrorHandler(RabbitListenerErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the
RabbitListenerErrorHandler
to invoke if the listener method throws an exception. - setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
- setErrorHandlerLoggerName(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name (category) of the logger used to log exceptions thrown by the error handler.
- setErrorRoutingKeyPrefix(String) - Method in class org.springframework.amqp.rabbit.retry.RepublishMessageRecoverer
- setException(Throwable) - Method in class org.springframework.amqp.support.converter.RemoteInvocationResult
-
Set the exception thrown by an unsuccessful invocation of the target method, if any.
- setExceptionHandler(ExceptionHandler) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setExchange(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setExchange(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The name of the default exchange to use for send operations when none is specified.
- setExchange(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setExchangeName(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setExchangeType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setExchangeType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true for an exclusive consumer.
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set if a single consumer in the container will have exclusive use of the queues, preventing other consumers from receiving messages from the queue(s).
- setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set to true for an exclusive consumer - if true, the
consumers per queue
must be 1. - setExclusive(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Set to true for an exclusive consumer - if true, the concurrency must be 1.
- setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setExclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a
ConditionalExceptionLogger
for logging exclusive consumer failures. - setExecutor(Executor) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Provide an Executor for use by the Rabbit ConnectionFactory when creating connections.
- setExpiration(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setExpiration(String) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the message expiration.
- setExpirationIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setExplicitDeclarationsOnly(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set to true to only declare
Declarable
beans that are explicitly configured to be declared by this admin. - setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setExposeListenerChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set whether to expose the listener Rabbit Channel to a registered
ChannelAwareMessageListener
as well as toRabbitTemplate
calls. - setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setFailedDeclarationRetryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the interval between passive queue declaration attempts in milliseconds.
- setFailedDeclarationRetryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setFilter(Filter) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setFinalRetryForMessageWithNoId(boolean) - Method in class org.springframework.amqp.core.MessageProperties
- setForceCloseChannel(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to force close the channel if the consumer threads don't respond to a shutdown.
- setForceStop(boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set to true to stop the container after the current message(s) are processed and requeue any prefetched.
- setForceStop(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true to stop the container after the current message(s) are processed and requeue any prefetched.
- setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setGenerateId(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Apply prefetch to the entire channel.
- setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Apply prefetch to the entire channel.
- setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Apply prefetchCount to the entire channel.
- setGlobalQos(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Apply prefetch to the entire channel.
- setGroup(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the group for the corresponding listener container.
- setGroupId(String) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.groupId(String)
. - setGroupSequence(long) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.groupSequence(long)
. - setHandlerAdapter(HandlerAdapter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
-
Set the
HandlerAdapter
to use to invoke the method processing an incomingMessage
. - setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setHeader(String, Object) - Method in class org.springframework.amqp.core.MessageProperties
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
-
Set the
AmqpHeaderMapper
implementation to use to map the standard AMQP headers. - setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
-
Set the
AmqpHeaderMapper
to use to map AMQP headers to and from standard message headers. - setHeaders(Map<String, Object>) - Method in class org.springframework.amqp.core.MessageProperties
-
Set headers.
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setHost(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setHostName(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- setHostName(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- setId(String) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Set the correlation id.
- setId(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.AbstractJavaTypeMapper
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Set a map of type Ids (in the "__TypeId__" header) to classes.
- setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setIdleEventInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
How often to emit
ListenerContainerIdleEvent
s in milliseconds. - setIdleEventInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
How often to publish idle container events.
- setIgnoreContentType(boolean) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
Flag to signal that the content type should be ignored and the deserializer used irrespective if it is a text message.
- setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
-
Set to true to ignore exceptions such as mismatched properties when declaring.
- setIgnoreDeclarationExceptions(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- setIgnoreDeclarationExceptions(Boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setIgnoreExceptions(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setIncludeCallerData(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
If true, the caller data will be available in the target AMQP message.
- setInferredArgumentType(Type) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the inferred target argument type when using a method-level
@RabbitListener
. - setInternal(boolean) - Method in class org.springframework.amqp.core.AbstractExchange
-
Set the internal flag.
- setjavaLangErrorHandler(AbstractMessageListenerContainer.JavaLangErrorHandler) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Provide a JavaLangErrorHandler implementation; by default,
System.exit(99)
is called. - setJavaTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- setKeyStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store resource (e.g.
- setKeyStore(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setKeyStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setKeyStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm used when creating the key store, default
SunX509
. - setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store pass phrase - overrides the property in
RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource)
. - setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setKeyStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setKeyStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a Resource pointing to the key store.
- setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store type - overrides the property in
RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource)
. - setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setKeyStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setLastInBatch(boolean) - Method in class org.springframework.amqp.core.MessageProperties
-
Set to true to indicate these properties are for the last message in a batch.
- setLayout(Layout<ILoggingEvent>) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setLayout(Layout<? extends Serializable>) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setLeaderLocator(String) - Method in class org.springframework.amqp.core.Queue
-
Set the leader locator strategy argument for this queue.
- setLenientFallback(boolean) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify whether to apply a lenient fallback to the default
ConnectionFactory
if no specificConnectionFactory
could be found for the current lookup key. - setLevel(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDeflaterPostProcessor
-
Set the deflater compression level.
- setListenerId(String) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setListenerId(String) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
-
Set the listener id.
- setListenerId(String) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
- setLocallyTransacted(boolean) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
True if the channel is locally transacted.
- setLookupKeyQualifier(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a qualifier that will prefix the connection factory lookup key; default none.
- setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set to true to enable the receipt of returned messages that cannot be delivered in the form of a
AmqpMessageReturnedException
. - setMandatory(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set the mandatory flag when sending messages; only applies if a
returnCallback
had been provided. - setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- setMandatoryExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- setMandatoryExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- setMandatoryPublish(boolean) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- setMarshaller(Marshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the
Marshaller
to be used by this message converter. - setMaxBodyLength(int) - Static method in class org.springframework.amqp.core.Message
-
Set the maximum length of a test message body to render as a String in
Message.toString()
. - setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMaxConcurrentConsumers(int) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Sets an upper limit to the number of consumers; defaults to 'concurrentConsumers'.
- setMaxConcurrentConsumers(Integer) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setMaxInboundMessageBodySize(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the maximum body size of inbound (received) messages in bytes.
- setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setMaxSenderRetries(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setMessageAckListener(MessageAckListener) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set a
MessageAckListener
to use when ack a message(messages) inAcknowledgeMode.AUTO
mode. - setMessageAckListener(MessageAckListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a
MessageAckListener
to use when ack a message(messages) inAcknowledgeMode.AUTO
mode. - setMessageAckListener(MessageAckListener) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set a
MessageAckListener
to use when ack a message(messages) inAcknowledgeMode.AUTO
mode. - setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set the message converter for this template.
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the converter that will convert incoming Rabbit messages to listener method arguments, and objects returned from listener methods back to Rabbit messages.
- setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
- setMessageConverter(MessageConverter) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
The preferred way for a container factory to pass a message converter to the endpoint's adapter.
- setMessageConverter(MessageConverter) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
-
Set a converter for
RabbitStreamTemplate.convertAndSend(Object)
operations. - setMessageConverter(MessageConverter) - Method in class org.springframework.amqp.rabbit.listener.adapter.AmqpMessageHandlerMethodFactory
- setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setMessageCount(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the message count.
- setMessageCountIfAbsent(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.annotation.RabbitListenerAnnotationBeanPostProcessor
-
Set the
MessageHandlerMethodFactory
to use to configure the message listener responsible to serve an endpoint detected by this processor. - setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the
MessageHandlerMethodFactory
to use to build theInvocableHandlerMethod
responsible to manage the invocation of this endpoint. - setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the
MessageHandlerMethodFactory
to use to configure the message listener responsible to serve an endpoint detected by this processor. - setMessageId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setMessageId(String) - Method in class org.springframework.amqp.core.MessageProperties
- setMessageIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setMessageKeyGenerator(MessageKeyGenerator) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
-
Set the
MessageListener
to invoke when a message matching the endpoint is received. - setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the
MessageListener
. - setMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set the
MessagePropertiesConverter
for this template. - setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the
MessagePropertiesConverter
for this listener container. - setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
- setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.rabbit.stream.retry.StreamRetryOperationsInterceptorFactoryBean
- setMessagesPerAck(int) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set the number of messages to receive before acknowledging (success).
- setMessagesPerAck(Integer) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set the number of messages to receive before acknowledging (success).
- setMethod(Method) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set the method to invoke to process a message managed by this endpoint.
- setMetricsCollector(MetricsCollector) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setMicrometerEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Set to false to disable micrometer listener timers.
- setMicrometerEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Set to false to disable micrometer listener timers.
- setMicrometerEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
-
Set to false to disable micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Set additional tags for the Micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
-
Set additional tags for the Micrometer listener timers.
- setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMismatchedQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Prevent the container from starting if any of the queues defined in the context have mismatched arguments (TTL etc.).
- setMismatchedQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setMissingQueuePublisher(Consumer<String>) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the publisher for a missing queue event.
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
If all the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
If all the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
- setMissingQueuesFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If all the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
- setMissingQueuesFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set how often to run a task to check for failed consumers and idle containers.
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set how often to run a task to check for failed consumers and idle containers.
- setMonitorInterval(long) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- setName(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setNativeListener(boolean) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
-
Set to true to create a container supporting a native RabbitMQ Stream message.
- setNewMessageIdentifier(NewMessageIdentifier) - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
- setNioParams(NioParams) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setNodeLocator(NodeLocator<?>) - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
-
Set a
NodeLocator
to use to find the node address for the leader. - setNoLocal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set to true for an no-local consumer.
- setNoLocal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setNoLocalReplyConsumer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set to true for a no-local consumer.
- setNotRunning() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- setNullAsOptionalEmpty(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
When true, if jackson decodes the body as
null
convert toOptional.empty()
instead of returning the original body. - setObservationConvention(RabbitListenerObservationConvention) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
-
Set an observation convention; used to add additional key/values to observations.
- setObservationConvention(RabbitListenerObservationConvention) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set an observation convention; used to add additional key/values to observations.
- setObservationConvention(RabbitTemplateObservationConvention) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set an observation convention; used to add additional key/values to observations.
- setObservationConvention(RabbitStreamListenerObservationConvention) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Set a RabbitStreamListenerObservationConvention; used to add additional key/values to observations when using a
StreamMessageListener
. - setObservationEnabled(boolean) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Enable observation via micrometer; disables basic Micrometer timers enabled by
BaseRabbitListenerContainerFactory.setMicrometerEnabled(boolean)
. - setObservationEnabled(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Enable observation via micrometer.
- setObservationEnabled(boolean) - Method in class org.springframework.amqp.rabbit.listener.ObservableListenerContainer
-
Enable observation via micrometer; disables basic Micrometer timers enabled by
ObservableListenerContainer.setMicrometerEnabled(boolean)
. - setObservationEnabled(boolean) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
-
Set to true to enable Micrometer observation.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractCompressingPostProcessor
-
Set the order.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.AbstractDecompressingPostProcessor
-
Set the order.
- setOrder(int) - Method in class org.springframework.amqp.support.postprocessor.DelegatingDecompressingPostProcessor
-
Set the order.
- setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.amqp.rabbit.support.ExpressionFactoryBean
- setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setPassword(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the password for the amqp connection default "guest".
- setPassword(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set the password for the amqp connection default "guest".
- setPassword(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setPassword(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setPayloadConverter(MessageConverter) - Method in class org.springframework.amqp.support.converter.MessagingMessageConverter
-
Set the
MessageConverter
to use to convert the payload. - setPhase(int) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- setPhase(int) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setPhase(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setPhase(int) - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- setPhase(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the phase in which this container should be started and stopped.
- setPhase(int) - Method in class org.springframework.rabbit.stream.support.StreamAdmin
-
Set the phase; default is 0.
- setPhysicalCloseRequired(Channel, boolean) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Sets a ThreadLocal indicating the channel MUST be physically closed.
- setPoolConfigurer(BiConsumer<GenericObjectPool<Channel>, Boolean>) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
-
Add a consumer to configure the object pool.
- setPort(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setPort(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setPort(int) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- setPort(int) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- setPort(Integer) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setPort(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setPossibleAuthenticationFailureFatal(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- setPossibleAuthenticationFailureFatal(Boolean) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setPrefetchCount(int) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Tell the broker how many messages to send to each consumer in a single request.
- setPrefetchCount(Integer) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setPriority(Integer) - Method in class org.springframework.amqp.core.MessageProperties
- setPriority(Integer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the priority of this endpoint.
- setPriorityIfAbsentOrDefault(Integer) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setProducerCustomizer(ProducerCustomizer) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
-
Used to customize the
ProducerBuilder
before theProducer
is built. - setProjectionUsed(boolean) - Method in class org.springframework.amqp.core.MessageProperties
-
Set an internal flag used to communicate that conversion used projection; always false at the application level.
- setProperties(MessageProperties) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setPublisherChannelFactory(PublisherCallbackChannelFactory) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Set the factory to use to create
PublisherCallbackChannel
instances. - setPublisherConfirmType(CachingConnectionFactory.ConfirmType) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
-
Set the confirm type to use; default
CachingConnectionFactory.ConfirmType.NONE
. - setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set a custom publisher connection factory; the type does not need to be the same as this factory.
- setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- setPublisherConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- setPublisherReturns(boolean) - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- setPublishSequenceNumber(long) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the publish sequence number, if publisher confirms are enabled; set by the template.
- setPurgeAfterEach(boolean) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Purge the test queues after each test (JUnit 5).
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name of the queue(s) to receive messages from.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the queue names to use.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.DirectReplyToMessageListenerContainer
- setQueueNames(String...) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
-
Set the queue names.
- setQueueNames(String...) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
- setQueueNames(String...) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Set the queue names.
- setQueueOrTagToMethodName(Map<String, String>) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
-
Set the mapping of queue name or consumer tag to method name.
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the name of the queue(s) to receive messages from.
- setQueues(Queue...) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the queues to use.
- setRabbitAdmin(RabbitAdmin) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setRabbitOperations(RabbitOperations) - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
-
Set the
RabbitOperations
for the gateway. - setRabbitTemplate(RabbitTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
Set the
RabbitTemplate
to use. - setReceiveConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
A SpEL
Expression
to evaluate against eachreceive
queueName
, if the providedRabbitAccessor.getConnectionFactory()
is an instance ofAbstractRoutingConnectionFactory
. - setReceivedDelay(Integer) - Method in class org.springframework.amqp.core.MessageProperties
-
Deprecated, for removal: This API element is subject to removal in a future version.in favor of
MessageProperties.setReceivedDelayLong(Long)
- setReceivedDelayLong(Long) - Method in class org.springframework.amqp.core.MessageProperties
-
When a delayed message exchange is used the x-delay header on a received message contains the delay.
- setReceivedDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.amqp.core.MessageProperties
- setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReceivedExchange(String) - Method in class org.springframework.amqp.core.MessageProperties
- setReceivedExchangeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReceivedRoutingKey(String) - Method in class org.springframework.amqp.core.MessageProperties
- setReceivedRoutingKeyIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReceivedUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set the receive timeout - the future returned by the send and receive methods will be canceled when this timeout expires.
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Specify the receive timeout in milliseconds when using
receive()
methods (forsendAndReceive()
methods, refer toreplyTimeout
. - setReceiveTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
The time (in milliseconds) that a consumer should wait for data.
- setReceiveTimeout(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setRecoveryBackOff(BackOff) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the
BackOff
for interval between recovery attempts. - setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add a
RecoveryCallback
which is used for theretryTemplate.execute
. - setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a
RecoveryCallback
to invoke when retries are exhausted. - setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setRecoveryInterval(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Specify the interval between recovery attempts, in milliseconds.
- setRecoveryInterval(Long) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setRecoveryListener(RecoveryListener) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
-
Set a
RecoveryListener
that will be added to each connection created. - setRedeclareManualDeclarations(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Normally, when a connection is recovered, the admin only recovers auto-delete queues, etc., that are declared as beans in the application context.
- setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setRedelivered(Boolean) - Method in class org.springframework.amqp.core.MessageProperties
- setRedeliveredIfAbsent(Boolean) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition property corresponding to the specified attributeName with the reference to a bean identified by the value of that attribute if the attribute is defined in the given element.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the specified bean definition property with the reference to a bean.
- setRejectManual(boolean) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
-
Set to false to NOT reject a fatal message when MANUAL ack mode is being used.
- setReplyAddress(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
An address for replies; if not provided, a temporary exclusive, auto-delete queue will be used for each reply, unless RabbitMQ supports 'amq.rabbitmq.reply-to'
- setReplyContentType(String) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set the reply content type.
- setReplyContentType(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the reply content type.
- setReplyErrorHandler(ErrorHandler) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
When using a direct reply-to container for request/reply operations, set an error handler to be invoked when a reply delivery fails (e.g.
- setReplyPostProcessor(ReplyPostProcessor) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Set a
ReplyPostProcessor
to post process a response message before it is sent. - setReplyPostProcessor(ReplyPostProcessor) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a
ReplyPostProcessor
to post process a response message before it is sent. - setReplyPostProcessorProvider(Function<String, ReplyPostProcessor>) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Set a function to provide a reply post processor; it will be used if there is no replyPostProcessor on the rabbit listener annotation.
- setReplyRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Set a
RecoveryCallback
to invoke when retries are exhausted. - setReplyTimeout(long) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Specify the timeout in milliseconds to be used when waiting for a reply Message when using one of the sendAndReceive methods.
- setReplyTo(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReplyTo(String) - Method in class org.springframework.amqp.core.MessageProperties
- setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReplyToAddress(Address) - Method in class org.springframework.amqp.core.MessageProperties
- setReplyToAddressIfAbsent(Address) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setReplyToGroupId(String) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.replyToGroupId(String)
. - setReplyToIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setRequestedChannelMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setRequestedFrameMax(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setRequestedHeartbeat(int) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setRequestedHeartBeat(int) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setRequeueOnRollback(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
-
Set to true to requeue a message on rollback; default true.
- setResourceLoader(ResourceLoader) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the resource loader; used to resolve the key store and trust store
Resource
s to input streams. - setResponseAddress(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the default replyTo address to use when sending response messages.
- setResponseExchange(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the exchange to use when sending response messages.
- setResponseRoutingKey(String) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set the routing key to use when sending response messages.
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
When consuming multiple queues, set the interval between declaration attempts when only a subset of the queues were available (milliseconds).
- setRetryDeclarationInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
When consuming multiple queues, set the interval between declaration attempts when only a subset of the queues were available (milliseconds).
- setRetryOperations(RetryOperations) - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.config.BaseRabbitListenerContainerFactory
-
Set a
RetryTemplate
to use when sending replies; added to each message listener adapter. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set a retry template for auto declarations.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Add a
RetryTemplate
which will be used for all rabbit operations. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
-
Set a
RetryTemplate
to use when sending replies. - setReturned(boolean) - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
-
Indicate that a returned message has been received.
- setReturned(ReturnedMessage) - Method in class org.springframework.amqp.rabbit.connection.CorrelationData
-
Set the returned message and metadata.
- setReturnExceptions(boolean) - Method in class org.springframework.amqp.rabbit.listener.MethodRabbitListenerEndpoint
-
Set whether exceptions thrown by the listener should be returned to the sender using the normal
replyTo/@SendTo
semantics. - setReturnsCallback(RabbitTemplate.ReturnsCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set a callback to receive returned messages.
- setReturnType(ParameterizedTypeReference<C>) - Method in class org.springframework.amqp.rabbit.RabbitConverterFuture
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setRoutingKey(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
The value of a default routing key to use for send operations when none is specified.
- setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setRoutingKeyPattern(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setSaslConfig(SaslConfig) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setSaslConfig(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setSaslConfig(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Set the
SaslConfig
. - setSecureRandom(SecureRandom) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the secure random to use when initializing the
SSLContext
. - setSendConnectionFactorySelectorExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
A SpEL
Expression
to evaluate against each request message, if the providedRabbitAccessor.getConnectionFactory()
is an instance ofAbstractRoutingConnectionFactory
. - setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setSenderPoolSize(int) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setSerializer(Serializer<Object>) - Method in class org.springframework.amqp.support.converter.SerializerMessageConverter
-
The serializer to use for converting Java objects to message bodies.
- setSharedExecutor(ExecutorService) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setShouldDeclare(boolean) - Method in class org.springframework.amqp.core.AbstractDeclarable
-
Whether or not this object should be automatically declared by any
AmqpAdmin
. - setShouldDeclare(boolean) - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
The time to wait for workers in milliseconds after the container is stopped.
- setShutdownTimeout(long) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
-
Enable simple publisher confirms.
- setSimplePublisherConfirms(boolean) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
-
Enable simple publisher confirms.
- setSkipServerCertificateValidation(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not Server Side certificate has to be validated or not.
- setSMLCCustomizer(ContainerCustomizer<SimpleMessageListenerContainer>) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
-
Set a
ContainerCustomizer
that is invoked after a container is created and configured to enable further customization of the container. - setSocketConfigurator(SocketConfigurator) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setSocketFactory(SocketFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm to use; default TLSv1.1.
- setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setSslAlgorithm(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setSslPropertiesLocation(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setSslPropertiesLocation(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setSslPropertiesLocation(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
When
RabbitConnectionFactoryBean.setUseSSL(boolean)
is true, the SSL properties to use (optional). - setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setStartConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If
SimpleMessageListenerContainer.maxConcurrentConsumers
is greater thenSimpleMessageListenerContainer.concurrentConsumers
, andSimpleMessageListenerContainer.maxConcurrentConsumers
has not been reached, specifies the minimum time (milliseconds) between starting new consumers on demand. - setStartConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setStatefulRetryFatalWithNullMessageId(boolean) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set whether a message with a null messageId is fatal for the consumer when using stateful retry.
- setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setStopConsumerMinInterval(long) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
If
SimpleMessageListenerContainer.maxConcurrentConsumers
is greater thenSimpleMessageListenerContainer.concurrentConsumers
, and the number of consumers exceedsSimpleMessageListenerContainer.concurrentConsumers
, specifies the minimum time (milliseconds) between stopping idle consumers. - setStopConsumerMinInterval(Long) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- setStreamConverter(StreamMessageConverter) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- setStreamConverter(StreamMessageConverter) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
-
Set a converter to convert from
Message
toMessage
forRabbitStreamTemplate.send(Message)
andRabbitStreamTemplate.convertAndSend(Object)
methods. - setStreamListenerObservationConvention(RabbitStreamListenerObservationConvention) - Method in class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
-
Set a
RabbitStreamListenerObservationConvention
that is used when receiving native stream messages. - setStreamMessageRecoverer(StreamMessageRecoverer) - Method in class org.springframework.rabbit.stream.retry.StreamRetryOperationsInterceptorFactoryBean
-
Set a
StreamMessageRecoverer
to call when retries are exhausted. - setSubject(String) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.subject(String)
. - setSuperStreamRouting(Function<Message, String>) - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
-
Add a routing function, making the stream a super stream.
- setSupportedContentType(MimeType) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Set the supported content type; only the subtype is checked when decoding, e.g.
- setTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
-
Set the
ConsumerTagStrategy
to use when generating consumer tags. - setTargetBean(Object) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the target bean when using
@RabbitListener
. - setTargetConnectionFactories(Map<Object, ConnectionFactory>) - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
-
Specify the map of target ConnectionFactories, with the lookup key as key.
- setTargetMethod(Method) - Method in class org.springframework.amqp.core.MessageProperties
-
Set the target method when using a
@RabbitListener
. - setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set a task executor to use when using a
DirectReplyToMessageListenerContainer
. - setTaskExecutor(Executor) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set a task executor for the container - used to create the consumers not at runtime.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
-
Set a task executor to use for async operations.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
-
Override the default task executor.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
-
Set the task scheduler to expire timed out futures.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
-
Set the task scheduler to use for the task that monitors idle containers and failed consumers.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
-
Set the task scheduler to use for the task that monitors idle containers and failed consumers.
- setThreadFactory(ThreadFactory) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setTimestamp(Date) - Method in class org.springframework.amqp.core.MessageProperties
- setTimestampIfAbsent(Date) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setTo(String) - Method in class org.springframework.rabbit.stream.support.StreamMessageProperties
-
See
MessageBuilder.PropertiesBuilder.to(String)
. - setTopologyRecoveryEnabled(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set to true to enable amqp-client topology recovery.
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the transaction attribute to use when using an external transaction manager.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Set the transaction manager to use.
- setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultClassMapper
-
Specify a set of packages to trust during deserialization.
- setTrustedPackages(String...) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
Specify a set of packages to trust during deserialization.
- setTrustStore(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the key store resource (e.g.
- setTrustStore(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setTrustStore(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setTrustStoreAlgorithm(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the algorithm used when creating the trust store, default
SunX509
. - setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the trust store pass phrase - overrides the property in
RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource)
. - setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setTrustStorePassphrase(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setTrustStoreResource(Resource) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set a Resource pointing to the trust store.
- setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Set the trust store type - overrides the property in
RabbitConnectionFactoryBean.setSslPropertiesLocation(Resource)
. - setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setTrustStoreType(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setType(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setType(String) - Method in class org.springframework.amqp.core.MessageProperties
- setType(ListenerContainerFactoryBean.Type) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- setTypeIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Set the precedence for evaluating type information in message properties.
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.amqp.support.converter.DefaultJackson2JavaTypeMapper
-
Set the precedence for evaluating type information in message properties.
- setUnmarshaller(Unmarshaller) - Method in class org.springframework.amqp.support.converter.MarshallingMessageConverter
-
Set the
Unmarshaller
to be used by this message converter. - setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.AmqpManager
- setUpExchangeDeclaration() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setupListenerContainer(MessageListenerContainer) - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- setupListenerContainer(MessageListenerContainer) - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
-
Setup the specified message listener container with the model defined by this endpoint.
- setupMessageListener(MessageListener) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- setupMessageListener(MessageListener) - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
-
Setup the message listener to use.
- setupMessageListener(MessageListener) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- setUpSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Override this method to take complete control over the SSL setup.
- setUri(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setUri(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setUri(URI) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setUri(URI) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setUri(URI) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setUseChannelForCorrelation(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
When using direct reply-to, set this to true to avoid the server needing to send the correlation id in a reply header.
- setUseDirectReplyToContainer(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set whether to use a
DirectReplyToMessageListenerContainer
when direct reply-to is available and being used. - setUseNio(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not the factory should be configured to use Java NIO.
- setUseProjectionForInterfaces(boolean) - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
-
Set to true to use Spring Data projection to create the object if the inferred parameter type is an interface.
- setUsePublisherConnection(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
To avoid deadlocked connections, it is generally recommended to use a separate connection for publishers and consumers (except when a publisher is participating in a consumer transaction).
- setUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
-
Set the user for the amqp connection default "guest".
- setUser(String) - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
-
Set the user for the amqp connection default "guest".
- setUser(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setUserCorrelationId(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set to true to use correlation id provided by the message instead of generating the correlation id for request/reply scenarios.
- setUserId(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setUserId(String) - Method in class org.springframework.amqp.core.MessageProperties
- setUserIdExpression(Expression) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set an expression to be evaluated to set the userId message property if it evaluates to a non-null value and the property is not already set in the message to be sent.
- setUserIdExpressionString(String) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
Set an expression to be evaluated to set the userId message property if it evaluates to a non-null value and the property is not already set in the message to be sent.
- setUserIdIfAbsent(String) - Method in class org.springframework.amqp.core.MessageBuilderSupport
- setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setUsername(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setUsername(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setUseSsl(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setUseSsl(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- setUseSSL(boolean) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
-
Whether or not the factory should be configured to use SSL.
- setUseTemplateDefaultReceiveQueue(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitMessagingTemplate
-
When true, use the underlying
RabbitTemplate
's defaultReceiveQueue property (if configured) for receive only methods instead of thedefaultDestination
configured in this template. - setUseTemporaryReplyQueues(boolean) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
-
By default, when the broker supports it and no
replyAddress
is provided, send/receive methods will use Direct reply-to. - setValidator(Validator) - Method in class org.springframework.amqp.rabbit.listener.adapter.AmqpMessageHandlerMethodFactory
- setValidator(Validator) - Method in class org.springframework.amqp.rabbit.listener.MultiMethodRabbitListenerEndpoint
-
Set a payload validator.
- setValidator(Validator) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistrar
-
Set the validator to use if the default message handler factory is used.
- setValue(Object) - Method in class org.springframework.amqp.support.converter.RemoteInvocationResult
-
Set the result value returned by a successful invocation of the target method, if any.
- setValue(Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
- setValue(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the bean definition property corresponding to the specified attributeName with the value of that attribute if it is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
-
Populates the specified bean definition property with the value of the attribute whose name is provided if that attribute is defined in the given element.
- setVerifyHostname(boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setVerifyHostname(boolean) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
-
Enable server hostname verification for TLS connections.
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Builder
- setVirtualHost(String) - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- sharedConnectionEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Always use a shared Rabbit Connection.
- SharedConnectionNotInitializedException(String) - Constructor for exception org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer.SharedConnectionNotInitializedException
-
Create a new SharedConnectionNotInitializedException.
- shouldDeclare() - Method in class org.springframework.amqp.core.AbstractDeclarable
- shouldDeclare() - Method in interface org.springframework.amqp.core.Declarable
-
Whether or not this object should be automatically declared by any
AmqpAdmin
. - shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
- shouldGenerateIdAsFallback() - Method in class org.springframework.amqp.rabbit.config.QueueParser
- shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.AbstractExchangeParser
- shouldParseNameAsAliases() - Method in class org.springframework.amqp.rabbit.config.QueueParser
- shouldRequeue(boolean, Throwable, Log) - Static method in class org.springframework.amqp.rabbit.listener.support.ContainerUtils
-
Determine whether a message should be requeued; returns true if the throwable is a
MessageRejectedWhileStoppingException
or defaultRequeueRejected is true and there is not anAmqpRejectAndDontRequeueException
in the cause chain or if there is anImmediateRequeueAmqpException
in the cause chain. - shutdown() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Stop the shared Connection, call
AbstractMessageListenerContainer.shutdown(Runnable)
, and close this container. - shutdown(Runnable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Stop the shared Connection, call
AbstractMessageListenerContainer.shutdownAndWaitOrCallback(Runnable)
, and close this container. - shutdownAndWaitOrCallback(Runnable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- shutdownAndWaitOrCallback(Runnable) - Method in class org.springframework.amqp.rabbit.listener.DirectMessageListenerContainer
- shutdownAndWaitOrCallback(Runnable) - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
- ShutDownChannelListener - Interface in org.springframework.amqp.rabbit.connection
-
Functional sub interface enabling a lambda for the onShutDown method.
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory
- shutdownCompleted(ShutdownSignalException) - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- simple - Enum constant in enum class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean.Type
- simple - Enum constant in enum class org.springframework.amqp.rabbit.test.context.SpringRabbitTest.ContainerType
- SIMPLE - Enum constant in enum class org.springframework.amqp.rabbit.connection.CachingConnectionFactory.ConfirmType
-
Use
RabbitTemplate#waitForConfirms()
orwaitForConfirmsOrDie()
within scoped operations. - SimpleAmqpHeaderMapper - Class in org.springframework.amqp.support
-
Simple implementation of
AmqpHeaderMapper
. - SimpleAmqpHeaderMapper() - Constructor for class org.springframework.amqp.support.SimpleAmqpHeaderMapper
- SimpleBatchingStrategy - Class in org.springframework.amqp.rabbit.batch
-
A simple batching strategy that supports only one exchange/routingKey; includes a batch size, a batched message size limit and a timeout.
- SimpleBatchingStrategy(int, int, long) - Constructor for class org.springframework.amqp.rabbit.batch.SimpleBatchingStrategy
- SimpleConnection - Class in org.springframework.amqp.rabbit.connection
-
Simply a Connection.
- SimpleConnection(Connection, int) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
- SimpleConnection(Connection, int, BackOffExecution) - Constructor for class org.springframework.amqp.rabbit.connection.SimpleConnection
-
Construct an instance with the
BackOffExecution
arguments. - SimpleMessageConverter - Class in org.springframework.amqp.support.converter
-
Implementation of
MessageConverter
that can work with Strings, Serializable instances, or byte arrays. - SimpleMessageConverter() - Constructor for class org.springframework.amqp.support.converter.SimpleMessageConverter
- SimpleMessageListenerContainer - Class in org.springframework.amqp.rabbit.listener
- SimpleMessageListenerContainer() - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Default constructor for convenient dependency injection via setters.
- SimpleMessageListenerContainer(ConnectionFactory) - Constructor for class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
-
Create a listener container from the connection factory (mandatory).
- SimplePropertyValueConnectionNameStrategy - Class in org.springframework.amqp.rabbit.connection
-
A
ConnectionNameStrategy
that returns the value of a (required) property. - SimplePropertyValueConnectionNameStrategy(String) - Constructor for class org.springframework.amqp.rabbit.connection.SimplePropertyValueConnectionNameStrategy
- SimpleRabbitListenerContainerFactory - Class in org.springframework.amqp.rabbit.config
-
A
RabbitListenerContainerFactory
implementation to build a regularSimpleMessageListenerContainer
. - SimpleRabbitListenerContainerFactory() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- SimpleRabbitListenerEndpoint - Class in org.springframework.amqp.rabbit.config
-
A
RabbitListenerEndpoint
simply providing theMessageListener
to invoke to process an incoming message for this endpoint. - SimpleRabbitListenerEndpoint() - Constructor for class org.springframework.amqp.rabbit.config.SimpleRabbitListenerEndpoint
- SimpleResourceHolder - Class in org.springframework.amqp.rabbit.connection
-
Central helper that manages resources per thread to be used by resource management code.
- SimpleRoutingConnectionFactory - Class in org.springframework.amqp.rabbit.connection
-
An
AbstractRoutingConnectionFactory
implementation which gets alookupKey
for currentConnectionFactory
from thread-bound resource by key of the instance of thisConnectionFactory
. - SimpleRoutingConnectionFactory() - Constructor for class org.springframework.amqp.rabbit.connection.SimpleRoutingConnectionFactory
- singleActiveConsumer() - Method in class org.springframework.amqp.core.QueueBuilder
-
Set the 'x-single-active-consumer' queue argument.
- SmartMessageConverter - Interface in org.springframework.amqp.support.converter
-
An extended
MessageConverter
SPI with conversion hint support. - sort(Collection<MessagePostProcessor>) - Static method in class org.springframework.amqp.support.postprocessor.MessagePostProcessorUtils
- SPRING_AUTO_DECOMPRESS - Static variable in class org.springframework.amqp.core.MessageProperties
- SPRING_BATCH_FORMAT - Static variable in class org.springframework.amqp.core.MessageProperties
- SPRING_REPLY_CORRELATION - Static variable in class org.springframework.amqp.support.AmqpHeaders
- SPRING_REPLY_TO_STACK - Static variable in class org.springframework.amqp.support.AmqpHeaders
- SpringRabbitTest - Annotation Interface in org.springframework.amqp.rabbit.test.context
-
Adds infrastructure beans to a Spring test context; do not use with Spring Boot since it has its own auto configuration mechanism.
- SpringRabbitTest.ContainerType - Enum Class in org.springframework.amqp.rabbit.test.context
-
Container type.
- spy() - Element in annotation interface org.springframework.amqp.rabbit.test.RabbitListenerTest
-
Set to true to create a Mockito spy on the listener.
- start() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- start() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- start() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- start() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- start() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- start() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- start() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- start() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- start() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- start() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Start this container.
- start() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- start() - Method in class org.springframework.amqp.rabbit.listener.MicrometerHolder
- start() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- start() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- start() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- start() - Method in class org.springframework.rabbit.stream.support.StreamAdmin
- stateful() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateful retry interceptor.
- StatefulRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateful retry interceptor for use in a message listener container, giving you a large amount of control over the behaviour of a container when a listener fails.
- StatefulRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
- stateless() - Static method in class org.springframework.amqp.rabbit.config.RetryInterceptorBuilder
-
Create a builder for a stateless retry interceptor.
- StatelessRetryOperationsInterceptorFactoryBean - Class in org.springframework.amqp.rabbit.config
-
Convenient factory bean for creating a stateless retry interceptor for use in a message listener container, giving you a large amount of control over the behaviour of a container when a listener fails.
- StatelessRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
- stop() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- stop() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- stop() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- stop() - Method in class org.springframework.amqp.rabbit.connection.LocalizedQueueConnectionFactory
- stop() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- stop() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- stop() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- stop() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- stop() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- stop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
-
Stop this container.
- stop() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- stop() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- stop() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- stop() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- stop() - Method in class org.springframework.rabbit.stream.support.StreamAdmin
- stop(long, TimeUnit, boolean) - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- stop(Runnable) - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- stopNow - Variable in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- stream() - Method in class org.springframework.amqp.core.QueueBuilder
-
Set the queue argument to declare a queue of type 'stream' instead of 'classic'.
- STREAM_LISTENER_OBSERVATION - Enum constant in enum class org.springframework.rabbit.stream.micrometer.RabbitStreamListenerObservation
-
Observation for Rabbit stream listeners.
- STREAM_TEMPLATE_OBSERVATION - Enum constant in enum class org.springframework.rabbit.stream.micrometer.RabbitStreamTemplateObservation
-
Observation for
RabbitStreamTemplate
s. - StreamAdmin - Class in org.springframework.rabbit.stream.support
-
Used to provision streams.
- StreamAdmin(Environment, Consumer<StreamCreator>) - Constructor for class org.springframework.rabbit.stream.support.StreamAdmin
-
Construct with the provided parameters.
- StreamListenerContainer - Class in org.springframework.rabbit.stream.listener
-
A listener container for RabbitMQ Streams.
- StreamListenerContainer(Environment) - Constructor for class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Construct an instance using the provided environment.
- StreamListenerContainer(Environment, Codec) - Constructor for class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Construct an instance using the provided environment and codec.
- streamMessageConverter() - Method in interface org.springframework.rabbit.stream.producer.RabbitStreamOperations
-
Return the stream message converter.
- streamMessageConverter() - Method in class org.springframework.rabbit.stream.producer.RabbitStreamTemplate
- StreamMessageConverter - Interface in org.springframework.rabbit.stream.support.converter
-
Converts between
Message
andMessage
. - StreamMessageListener - Interface in org.springframework.rabbit.stream.listener
-
A message listener that receives native stream messages.
- StreamMessageListenerAdapter - Class in org.springframework.rabbit.stream.listener.adapter
-
A listener adapter that receives native stream messages.
- StreamMessageListenerAdapter(Object, Method, boolean, RabbitListenerErrorHandler) - Constructor for class org.springframework.rabbit.stream.listener.adapter.StreamMessageListenerAdapter
-
Construct an instance with the provided arguments.
- StreamMessageProperties - Class in org.springframework.rabbit.stream.support
-
MessageProperties
extension for stream messages. - StreamMessageProperties() - Constructor for class org.springframework.rabbit.stream.support.StreamMessageProperties
-
Create a new instance.
- StreamMessageProperties(MessageHandler.Context) - Constructor for class org.springframework.rabbit.stream.support.StreamMessageProperties
-
Create a new instance with the provided context.
- StreamMessageRecoverer - Interface in org.springframework.rabbit.stream.retry
-
Implementations of this interface can handle failed messages after retries are exhausted.
- streamPort() - Static method in class org.springframework.amqp.rabbit.junit.AbstractTestContainerTests
- StreamRabbitListenerContainerFactory - Class in org.springframework.rabbit.stream.config
-
Factory for StreamListenerContainer.
- StreamRabbitListenerContainerFactory(Environment) - Constructor for class org.springframework.rabbit.stream.config.StreamRabbitListenerContainerFactory
-
Construct an instance using the provided environment.
- StreamRetryOperationsInterceptorFactoryBean - Class in org.springframework.rabbit.stream.retry
-
Convenient factory bean for creating a stateless retry interceptor for use in a
StreamListenerContainer
when consuming native stream messages, giving you a large amount of control over the behavior of a container when a listener fails. - StreamRetryOperationsInterceptorFactoryBean() - Constructor for class org.springframework.rabbit.stream.retry.StreamRetryOperationsInterceptorFactoryBean
- StreamSendException - Exception in org.springframework.rabbit.stream.producer
-
Used to complete the future exceptionally when sending fails.
- StreamSendException(String, int) - Constructor for exception org.springframework.rabbit.stream.producer.StreamSendException
-
Construct an instance with the provided message.
- stringToSaslConfig(String, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
-
Convert a String value to a
SaslConfig
. - success(Object, String) - Method in class org.springframework.amqp.rabbit.listener.MicrometerHolder
- superStream(String) - Static method in class org.springframework.rabbit.stream.config.SuperStreamBuilder
-
Creates a builder for Super Stream.
- superStream(String, int) - Static method in class org.springframework.rabbit.stream.config.SuperStreamBuilder
-
Creates a builder for Super Stream.
- superStream(String, String) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Enable Single Active Consumer on a Super Stream, with one consumer.
- superStream(String, String, int) - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
-
Enable Single Active Consumer on a Super Stream with the provided number of consumers.
- SuperStream - Class in org.springframework.rabbit.stream.config
-
Create Super Stream Topology
Declarable
s. - SuperStream(String, int) - Constructor for class org.springframework.rabbit.stream.config.SuperStream
-
Create a Super Stream with the provided parameters.
- SuperStream(String, int, BiFunction<String, Integer, List<String>>) - Constructor for class org.springframework.rabbit.stream.config.SuperStream
-
Create a Super Stream with the provided parameters.
- SuperStream(String, int, BiFunction<String, Integer, List<String>>, Map<String, Object>) - Constructor for class org.springframework.rabbit.stream.config.SuperStream
-
Create a Super Stream with the provided parameters.
- SuperStream(String, int, Map<String, Object>) - Constructor for class org.springframework.rabbit.stream.config.SuperStream
-
Create a Super Stream with the provided parameters.
- SuperStreamBuilder - Class in org.springframework.rabbit.stream.config
-
Builds a Spring AMQP Super Stream using a fluent API.
- SuperStreamBuilder() - Constructor for class org.springframework.rabbit.stream.config.SuperStreamBuilder
- supportsContext(Observation.Context) - Method in interface org.springframework.amqp.rabbit.support.micrometer.RabbitListenerObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.amqp.rabbit.support.micrometer.RabbitTemplateObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.rabbit.stream.micrometer.RabbitStreamListenerObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.rabbit.stream.micrometer.RabbitStreamTemplateObservationConvention
- supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.amqp.rabbit.junit.RabbitAvailableCondition
- supportsParameter(MethodParameter) - Method in class org.springframework.amqp.rabbit.listener.adapter.ContinuationHandlerMethodArgumentResolver
- suppressDeclaration() - Method in class org.springframework.amqp.core.ExchangeBuilder
-
Switch to disable declaration of the exchange by any admin.
- switchContext(Object) - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
-
Acquire ownership of another thread's channel(s) after that thread called
ThreadChannelConnectionFactory.prepareSwitchContext()
. - SYSTEM - Static variable in class org.springframework.amqp.core.ExchangeTypes
-
System exchange.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
MessageProperties.setDelayLong(Long)