Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractAmqpChannel - Class in org.springframework.integration.amqp.channel
-
The base
AbstractMessageChannel
implementation for AMQP. - AbstractAmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
A base
AbstractReplyProducingMessageHandler
extension for AMQP message handlers. - AbstractAmqpOutboundEndpoint() - Constructor for class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- AbstractAmqpOutboundEndpoint.CorrelationDataWrapper - Class in org.springframework.integration.amqp.outbound
- AbstractMessageListenerContainerSpec<S extends AbstractMessageListenerContainerSpec<S,
C>, C extends org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl -
Base class for container specs for containers that extend
AbstractMessageListenerContainer
. - AbstractMessageListenerContainerSpec(C) - Constructor for class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- ackTimeout(long) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- addDelayProperty(Message<?>, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- addQueueNames(String...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- addQueues(Queue...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- advice(Advice...) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- adviceChain - Variable in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
- afterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set
MessagePostProcessor
s that will be applied after message reception, before invoking theMessageListener
. - afterShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- alwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set to true to always requeue on transaction rollback with an external TransactionManager.
- Amqp - Class in org.springframework.integration.amqp.dsl
-
Factory class for AMQP components.
- AMQP_RAW_MESSAGE - Static variable in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
-
Header name/retry context variable for the raw received message.
- AmqpAckCallback(AmqpMessageSource.AmqpAckInfo) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- AmqpAckCallbackFactory() - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
- AmqpAckInfo(Connection, Channel, boolean, GetResponse) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- AmqpAsyncOutboundGatewaySpec - Class in org.springframework.integration.amqp.dsl
- AmqpAsyncOutboundGatewaySpec(AsyncRabbitTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpAsyncOutboundGatewaySpec
- AmqpBaseInboundChannelAdapterSpec<S extends AmqpBaseInboundChannelAdapterSpec<S>> - Class in org.springframework.integration.amqp.dsl
-
The base
MessageProducerSpec
implementation for aAmqpInboundChannelAdapter
. - AmqpBaseInboundChannelAdapterSpec(AmqpInboundChannelAdapter) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
- AmqpBaseInboundGatewaySpec<S extends AmqpBaseInboundGatewaySpec<S>> - Class in org.springframework.integration.amqp.dsl
-
A base
MessagingGatewaySpec
implementation forAmqpInboundGateway
endpoint options. - AmqpBaseInboundGatewaySpec(AmqpInboundGateway) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- AmqpBaseOutboundEndpointSpec<S extends AmqpBaseOutboundEndpointSpec<S,
E>, E extends AbstractAmqpOutboundEndpoint> - Class in org.springframework.integration.amqp.dsl -
The base
MessageHandlerSpec
forAbstractAmqpOutboundEndpoint
s. - AmqpBaseOutboundEndpointSpec() - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- amqpChannelFactoryBean - Variable in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpChannelFactoryBean - Class in org.springframework.integration.amqp.config
-
If point-to-point, we send to the default exchange with the routing key equal to "[beanName]" and we declare that same Queue and register a listener if message-driven or poll explicitly otherwise.
- AmqpChannelFactoryBean() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- AmqpChannelFactoryBean(boolean) - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- AmqpChannelParser - Class in org.springframework.integration.amqp.config
-
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration AMQP namespace.
- AmqpChannelParser() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelParser
- AmqpHeaderMapper - Interface in org.springframework.integration.amqp.support
-
A convenience interface that extends
RequestReplyHeaderMapper
, parameterized withMessageProperties
. - AmqpInboundChannelAdapter - Class in org.springframework.integration.amqp.inbound
-
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundChannelAdapter(MessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Construct an instance using the provided container.
- AmqpInboundChannelAdapter.BatchListener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundChannelAdapter.BatchMode - Enum Class in org.springframework.integration.amqp.inbound
-
Defines the payload type when the listener container is configured with consumerBatchEnabled.
- AmqpInboundChannelAdapter.Listener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundChannelAdapterDMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an inbound channel adapter with a
DirectMessageListenerContainer
. - AmqpInboundChannelAdapterDMLCSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
- AmqpInboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'inbound-channel-adapter' element.
- AmqpInboundChannelAdapterSMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an inbound channel adapter with a
SimpleMessageListenerContainer
. - AmqpInboundChannelAdapterSMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
- AmqpInboundChannelAdapterSpec<S extends AmqpInboundChannelAdapterSpec<S,
C>, C extends org.springframework.amqp.rabbit.listener.MessageListenerContainer> - Class in org.springframework.integration.amqp.dsl -
A
MessageProducerSpec
forAmqpInboundChannelAdapter
s. - AmqpInboundChannelAdapterSpec(MessageListenerContainerSpec<?, C>) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
- AmqpInboundGateway - Class in org.springframework.integration.amqp.inbound
-
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundGateway(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- AmqpInboundGateway(MessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Construct
AmqpInboundGateway
based on the providedMessageListenerContainer
to receive request messages andAmqpTemplate
to send replies. - AmqpInboundGateway.Listener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundGatewayDMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a gateway with a
DirectMessageListenerContainer
. - AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- AmqpInboundGatewayParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'inbound-gateway' element.
- AmqpInboundGatewaySMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a gateway with a
SimpleMessageListenerContainer
. - AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- AmqpInboundGatewaySpec<S extends AmqpInboundGatewaySpec<S,
C>, C extends org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl -
An
AmqpBaseInboundGatewaySpec
implementation for aAmqpInboundGateway
. - AmqpInboundGatewaySpec(AbstractMessageListenerContainerSpec<?, C>) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
- AmqpInboundPolledChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a polled AMQP inbound channel adapter.
- AmqpInboundPolledChannelAdapterSpec(ConnectionFactory, String) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- AmqpInboundPolledChannelAdapterSpec(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- AmqpMessageChannelSpec<S extends AmqpMessageChannelSpec<S,
T>, T extends AbstractAmqpChannel> - Class in org.springframework.integration.amqp.dsl -
An
AmqpPollableMessageChannelSpec
for a message-drivenPointToPointSubscribableAmqpChannel
. - AmqpMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- amqpMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpMessageHeaderErrorMessageStrategy - Class in org.springframework.integration.amqp.support
-
An
ErrorMessageStrategy
extension that adds the raw AMQP message as a header to theErrorMessage
. - AmqpMessageHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
- AmqpMessageSource - Class in org.springframework.integration.amqp.inbound
-
A pollable
MessageSource
for RabbitMQ. - AmqpMessageSource(ConnectionFactory, String) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource
- AmqpMessageSource(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource
- AmqpMessageSource.AmqpAckCallback - Class in org.springframework.integration.amqp.inbound
- AmqpMessageSource.AmqpAckCallbackFactory - Class in org.springframework.integration.amqp.inbound
- AmqpMessageSource.AmqpAckInfo - Class in org.springframework.integration.amqp.inbound
-
Information for building an AmqpAckCallback.
- AmqpNamespaceHandler - Class in org.springframework.integration.amqp.config
-
Namespace handler for the AMQP schema.
- AmqpNamespaceHandler() - Constructor for class org.springframework.integration.amqp.config.AmqpNamespaceHandler
- AmqpOutboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundChannelAdapterParser
- AmqpOutboundChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an outbound AMQP channel adapter.
- AmqpOutboundChannelAdapterSpec(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundChannelAdapterSpec
- AmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
Adapter that converts and sends Messages to an AMQP Exchange.
- AmqpOutboundEndpoint(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- AmqpOutboundEndpointSpec<S extends AmqpOutboundEndpointSpec<S>> - Class in org.springframework.integration.amqp.dsl
-
Base spec for outbound AMQP endpoints.
- AmqpOutboundEndpointSpec(AmqpTemplate, boolean) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
- AmqpOutboundGatewayParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundGatewayParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
- AmqpOutboundGatewaySpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an outbound AMQP gateway.
- AmqpOutboundGatewaySpec(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundGatewaySpec
- AmqpPollableMessageChannelSpec<S extends AmqpPollableMessageChannelSpec<S,
T>, T extends AbstractAmqpChannel> - Class in org.springframework.integration.amqp.dsl -
A
MessageChannelSpec
for aAbstractAmqpChannel
s. - AmqpPollableMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpPublishSubscribeMessageChannelSpec - Class in org.springframework.integration.amqp.dsl
- AmqpPublishSubscribeMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpPublishSubscribeMessageChannelSpec
- AsyncAmqpOutboundGateway - Class in org.springframework.integration.amqp.outbound
-
An outbound gateway where the sending thread is released immediately and the reply is sent on the async template's listener container thread.
- AsyncAmqpOutboundGateway(AsyncRabbitTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- asyncOutboundGateway(AsyncRabbitTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpAsyncOutboundGatewaySpec.
- autoDeclare(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set to true to automatically declare elements (queues, exchanges, bindings) in the application context during container start().
- autoStartup(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
B
- batchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a batching strategy to use when de-batching messages.
- BatchListener() - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
- batchMode(AmqpInboundChannelAdapter.BatchMode) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
Set the
AmqpInboundChannelAdapter.BatchMode
to use when the container is configured to support batching consumed records. - batchSize(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure the batch size.
- batchSize(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
The batch size to use.
- beforeShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- bindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set to true to bind the source message in the headers.
- BoundRabbitChannelAdvice - Class in org.springframework.integration.amqp.support
-
An advice that causes all downstream
RabbitOperations
operations to be executed on the same channel, as long as there are no thread handoffs, since the channel is bound to the thread. - BoundRabbitChannelAdvice(RabbitOperations) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that doesn't wait for confirms.
- BoundRabbitChannelAdvice(RabbitOperations, Duration) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that waits for publisher confirms (if configured and waitForConfirmsTimeout is not null).
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpChannelParser
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
- buildReply(MessageConverter, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- buildReturnedMessage(ReturnedMessage, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
C
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpMessageChannelSpec.
- channel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpMessageChannelSpec.
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure
channelTransacted
on both theRabbitTemplate
(for sends) andSimpleMessageListenerContainer
(for receives) when using Spring Integration 4.0. - checkDeliveryMode(Message<?>, MessageProperties, MessageDeliveryMode) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Check the delivery mode and update with the default if not already present.
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- configure(Consumer<StreamListenerContainer>) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Perform additional configuration of the container.
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundGatewayParser
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- configureContainer(Consumer<RabbitStreamMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- confirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which acks are send (publisher confirms).
- confirmCorrelationExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationFunction(Function<Message<?>, Object>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a
Function
to evaluate confirm correlation at runtime. - confirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which nacks are send (publisher confirms).
- confirmTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a timeout after which a nack will be synthesized if no publisher confirm has been received within that time.
- confirmTimeout(long) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set a timeout for the confirm result.
- consecutiveActiveTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- consecutiveIdleTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- CONSOLIDATED_HEADERS - Static variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Header containing
List<Map<String, Object>
headers when batch mode isAmqpInboundChannelAdapter.BatchMode.EXTRACT_PAYLOADS_WITH_HEADERS
. - consumerArguments(Map<String, Object>) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set consumer arguments.
- consumerBatchEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
Set to true to enable batching of consumed messages.
- consumerCustomizer(ConsumerCustomizer) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Set a consumer customizer.
- consumersPerQueue(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- consumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the implementation of
ConsumerTagStrategy
to generate consumer tags. - converter - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- convertPayload(Message) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- createCallback(AmqpMessageSource.AmqpAckInfo) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- createInstance() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- createMessageFromAmqp(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- createMessageFromPayload(Object, Channel, Map<String, Object>, long, List<Map<String, Object>>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
D
- deBatchingEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Determine whether the container should de-batch batched messages (true) or call the listener with the batch (false).
- DefaultAmqpHeaderMapper - Class in org.springframework.integration.amqp.support
-
Default implementation of
AmqpHeaderMapper
. - DefaultAmqpHeaderMapper(String[], String[]) - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the default delivery mode.
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure the delivery mode for messages that don't have an
AmqpHeaders.DELIVERY_MODE
header. - defaultReplyTo(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
The
defaultReplyTo
address with the form - defaultRequeueRejected(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- delay(int) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the value to set in the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayFunction(Function<Message<?>, Integer>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the function to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - destroy() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- destroy() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- DirectMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a
DirectMessageListenerContainer
. - DirectMessageListenerContainerSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- doDeclares() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- doInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- doReceive() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- doReceive(Long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- doStart() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doStart() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- doStop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doStop() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- doStop() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
E
- encoding(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- endpointInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Subclasses can override to perform any additional initialization.
- endpointInit() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- EndpointUtils - Class in org.springframework.integration.amqp.support
-
Utility methods for messaging endpoints.
- errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- errorMessagePayload(List<Message>, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
-
Return an
ListenerExecutionFailedException
or aManualAckListenerExecutionFailedException
depending on whether isManualAck is false or true. - errorMessagePayload(Message, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
-
Return an
ListenerExecutionFailedException
or aManualAckListenerExecutionFailedException
depending on whether isManualAck is false or true. - errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the error message strategy to use for returned (or negatively confirmed) messages.
- exchange(FanoutExchange) - Method in class org.springframework.integration.amqp.dsl.AmqpPublishSubscribeMessageChannelSpec
- exchangeName(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure an AMQP exchange name for sending messages.
- exchangeNameExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure a SpEL expression to evaluate an exchange name at runtime.
- exchangeNameExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure a SpEL expression to evaluate an exchange name at runtime.
- exchangeNameFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure a
Function
to evaluate an exchange name at runtime. - exclusive(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- exclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set a
ConditionalExceptionLogger
for logging exclusive consumer failures. - expectReply - Variable in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
- exposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- EXTRACT_PAYLOADS - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Payload is a
List<?>
where each element is the converted body of the Spring AMQP Message. - EXTRACT_PAYLOADS_WITH_HEADERS - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Payload is a
List<?>
where each element is the converted body of the Spring AMQP Message. - extractPayload(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure whether normal spring-messaging to AMQP message mapping is enabled.
- extractStandardHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Extract "standard" headers from an AMQP MessageProperties instance.
- extractUserDefinedHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Extract user-defined headers from an AMQP MessageProperties instance.
F
- failedDeclarationRetryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the interval between passive queue declaration attempts in milliseconds.
G
- generateCorrelationData(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- generateExchangeName(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- generateRoutingKey(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getAckInfo() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- getAdmin() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- getAmqpMessage() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- getAmqpTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- getBatchingStrategy() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- getBeanClassName(Element) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- getChannel() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- getChannel() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
-
Return the channel.
- getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
- getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
- getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- getComponentType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- getComponentType() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- getConfirmAckChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getConfirmCorrelationExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getConfirmNackChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getConfirmTimeout() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getConnection() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- getConnectionFactory() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- getCorrelationData() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
- getCorrelationDataGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getDefaultDeliveryMode() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getDeliveryTag() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
-
Return the delivery tag for the last failed message.
- getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- getExchange() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- getExchangeName() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Subclasses may override this method to return an Exchange name.
- getExchangeName() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- getExchangeName() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getExchangeNameExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getExchangeNameGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getFuture() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
- getGetResponse() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- getHeaderMapper() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- getHeaderMapper() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getInboundHeaderMapper() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- getInputChannelAttributeName() - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
- getIntegrationPatternType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- getMessage() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
- getMessageConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- getNackReason() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
- getObjectType() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- getPhase() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- getPhase() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- getPropertiesConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- getRabbitTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- getReplyCode() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- getReplyText() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- getReturnChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Subclasses may override this method to return a routing key.
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- getRoutingKey() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getRoutingKey() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- getRoutingKeyExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getRoutingKeyGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- getSendFailureChannel() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
- getSendSuccessChannel() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
- getStreamOperations() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Return the
RabbitStreamOperations
. - getUserData() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
H
- handleConfirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- handleMessageInternal(Message<?>) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
- handleRequestMessage(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- handleRequestMessage(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- hasExecutorInterceptors() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
- headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Configure the adapter's
AmqpHeaderMapper
; defaults toDefaultAmqpHeaderMapper
. - headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Configure the gateway's
AmqpHeaderMapper
; defaults toDefaultAmqpHeaderMapper
. - headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - headersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Determine whether the headers are mapped before the message is converted, or afterwards.
- headersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- headersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Determine whether the headers are mapped before the message is converted, or afterwards.
I
- id(String) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- id(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- idleEventInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
How often to emit
ListenerContainerIdleEvent
s in milliseconds. - inboundAdapter(Environment) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
-
Create an initial
RabbitStreamInboundChannelAdapterSpec
with the providedEnvironment
. - inboundAdapter(Environment, Codec) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
-
Create an initial
RabbitStreamInboundChannelAdapterSpec
with the providedEnvironment
. - inboundAdapter(ConnectionFactory, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpInboundChannelAdapterSpec using a
SimpleMessageListenerContainer
. - inboundAdapter(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpInboundChannelAdapterSpec using a
SimpleMessageListenerContainer
. - inboundAdapter(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewayDMLCSpec
with providedDirectMessageListenerContainer
. - inboundAdapter(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySMLCSpec
with providedSimpleMessageListenerContainer
. - inboundAdapter(StreamListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
-
Create an initial
RabbitStreamInboundChannelAdapterSpec
with the providedStreamListenerContainer
. - inboundGateway(ConnectionFactory, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySpec
. - inboundGateway(ConnectionFactory, AmqpTemplate, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySpec
. - inboundGateway(ConnectionFactory, AmqpTemplate, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySpec
. - inboundGateway(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySpec
. - inboundGateway(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
DirectMessageListenerContainerSpec
with providedDirectMessageListenerContainer
. - inboundGateway(DirectMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewayDMLCSpec
with providedDirectMessageListenerContainer
. - inboundGateway(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySMLCSpec
with providedSimpleMessageListenerContainer
. - inboundGateway(SimpleMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial
AmqpInboundGatewaySMLCSpec
with providedSimpleMessageListenerContainer
. - inboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure the inbound header mapper to use when
AmqpPollableMessageChannelSpec.extractPayload(boolean)
is true. - inboundMapper() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Construct a default inbound header mapper.
- inboundPolledAdapter(ConnectionFactory, String) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpInboundPolledChannelAdapterSpec.
- inboundPolledAdapter(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpInboundPolledChannelAdapterSpec.
- inboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- inboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- init() - Method in class org.springframework.integration.amqp.config.AmqpNamespaceHandler
- invoke(MethodInvocation) - Method in class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
- isAcknowledged() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- isAutoAck() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- isAutoStartup() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- isAutoStartup() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- isExtractPayload() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- isHeadersMappedLast() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isLazyConnect() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isLoggingEnabled() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- isRawMessageHeader() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- isRunning() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- isRunning() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- isRunning() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
L
- lazyConnect(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set to
false
to attempt to connect during endpoint start. - Listener() - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- Listener() - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
- listenerContainer - Variable in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- listenerContainer - Variable in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- listenerContainerSpec - Variable in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
- listenerContainerSpec - Variable in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
- lookupKeyQualifier(String) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set a qualifier that will prefix the connection factory lookup key; default none.
M
- ManualAckListenerExecutionFailedException - Exception in org.springframework.integration.amqp.support
-
A
ListenerExecutionFailedException
enhanced with the channel and delivery tag. - ManualAckListenerExecutionFailedException(String, Throwable, Channel, long, Message...) - Constructor for exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
-
Construct an instance with the provided properties.
- manualAcks - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- mapMessage(Message<?>, MessageConverter, AmqpHeaderMapper, boolean, boolean, MessageProperties) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map a reply o.s.m.Message to an o.s.a.core.Message.
- mapMessage(Message<?>, MessageConverter, AmqpHeaderMapper, MessageDeliveryMode, boolean) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map an o.s.m.Message to an o.s.a.core.Message.
- mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Only applies if the default header mapper is used.
- mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Provide the header names that should be mapped to a response from a
MessageHeaders
. - mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Only applies if the default header mapper is used.
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Only applies if the default header mapper is used.
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Provide the header names that should be mapped from a request to a
MessageHeaders
. - mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Provide the header names that should be mapped from a request to a
MessageHeaders
. - MappingUtils - Class in org.springframework.integration.amqp.support
-
Utility methods used during message mapping.
- mapReplyMessage(Message<?>, MessageConverter, AmqpHeaderMapper, MessageDeliveryMode, boolean) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map a reply o.s.m.Message to an o.s.a.core.Message.
- maxConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- maxSubscribers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Configure the adapter's
MessageConverter
; defaults toSimpleMessageConverter
. - messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Configure the gateway's
MessageConverter
; defaults toSimpleMessageConverter
. - messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- MessageListenerContainerSpec<S extends MessageListenerContainerSpec<S,
C>, C extends org.springframework.amqp.rabbit.listener.MessageListenerContainer> - Class in org.springframework.integration.amqp.dsl -
Base class for container specs.
- MessageListenerContainerSpec() - Constructor for class org.springframework.integration.amqp.dsl.MessageListenerContainerSpec
- messagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the
MessagePropertiesConverter
for this listener container. - messagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure
messagePropertiesConverter
on both theRabbitTemplate
(for sends) andSimpleMessageListenerContainer
(for receives). - messageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a
MessageRecoverer
when using retry within the adapter. - messageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a
MessageRecoverer
when using retry within the adapter. - MESSAGES - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Payload is a
List<Message<?>>
where each element is a message is converted from the Spring AMQP Message. - messagesPerAck(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- mismatchedQueuesFatal(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Prevent the container from starting if any of the queues defined in the context have mismatched arguments (TTL etc.).
- missingQueuesFatal(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
If all the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
- multiSend(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundChannelAdapterSpec
-
If true, and the message payload is an
Iterable
ofMessage
, send the messages in a single invocation of the template (same channel) and optionally wait for the confirms or die.
N
- NackedAmqpMessageException - Exception in org.springframework.integration.amqp.support
-
An exception representing a negatively acknowledged message from a publisher confirm.
- NackedAmqpMessageException(Message<?>, Object, String) - Constructor for exception org.springframework.integration.amqp.support.NackedAmqpMessageException
- noAutoAck() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
O
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- onCreate(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
- onMessageBatch(List<Message>, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
- org.springframework.integration.amqp.channel - package org.springframework.integration.amqp.channel
-
Provides classes related to AMQP-backed channels.
- org.springframework.integration.amqp.config - package org.springframework.integration.amqp.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.amqp.dsl - package org.springframework.integration.amqp.dsl
-
Provides AMQP Component support for the Java DSL.
- org.springframework.integration.amqp.inbound - package org.springframework.integration.amqp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.amqp.outbound - package org.springframework.integration.amqp.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.amqp.support - package org.springframework.integration.amqp.support
-
Provides AMQP support classes.
- outboundAdapter(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpOutboundEndpointSpec (adapter).
- outboundGateway(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpOutboundEndpointSpec (gateway).
- outboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure the outbound header mapper to use when
AmqpPollableMessageChannelSpec.extractPayload(boolean)
is true. - outboundMapper() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Construct a default outbound header mapper.
- outboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- outboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- outboundStreamAdapter(Environment, String) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
-
Create an initial
RabbitStreamMessageHandlerSpec
(adapter). - outboundStreamAdapter(RabbitStreamTemplate) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
-
Create an initial
RabbitStreamMessageHandlerSpec
(adapter).
P
- parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpOutboundChannelAdapterParser
- parseHandler(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
- performReceive(Long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- phase(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- PointToPointSubscribableAmqpChannel - Class in org.springframework.integration.amqp.channel
-
The
AbstractSubscribableAmqpChannel
implementation for one-to-one subscription over AMQP queue. - PointToPointSubscribableAmqpChannel(String, AbstractMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Construct an instance with the supplied name, container and template; default header mappers will be used if the message is mapped.
- PointToPointSubscribableAmqpChannel(String, AbstractMessageListenerContainer, AmqpTemplate, AmqpHeaderMapper, AmqpHeaderMapper) - Constructor for class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Construct an instance with the supplied name, container and template; default header mappers will be used if the message is mapped.
- PollableAmqpChannel - Class in org.springframework.integration.amqp.channel
-
A
PollableChannel
implementation that is backed by an AMQP Queue. - PollableAmqpChannel(String, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Construct an instance with the supplied name, template and default header mappers used if the template is a
RabbitTemplate
and the message is mapped. - PollableAmqpChannel(String, AmqpTemplate, AmqpHeaderMapper, AmqpHeaderMapper) - Constructor for class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Construct an instance with the supplied name, template and header mappers.
- pollableChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPollableMessageChannelSpec.
- pollableChannel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPollableMessageChannelSpec.
- populateStandardHeaders(Map<String, Object>, Map<String, Object>, MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Maps headers from a Spring Integration MessageHeaders instance to the MessageProperties of an AMQP Message.
- populateStandardHeaders(Map<String, Object>, MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Maps headers from a Spring Integration MessageHeaders instance to the MessageProperties of an AMQP Message.
- populateUserDefinedHeader(String, Object, MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- prefetchCount(int) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- prefetchCount(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- propertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- PublishSubscribeAmqpChannel - Class in org.springframework.integration.amqp.channel
-
The
AbstractSubscribableAmqpChannel
extension for pub-sub semantics based on theFanoutExchange
. - PublishSubscribeAmqpChannel(String, AbstractMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
Construct an instance with the supplied name, container and template; default header mappers will be used if the message is mapped.
- PublishSubscribeAmqpChannel(String, AbstractMessageListenerContainer, AmqpTemplate, AmqpHeaderMapper, AmqpHeaderMapper) - Constructor for class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
Construct an instance with the supplied name, container and template; default header mappers will be used if the message is mapped.
- publishSubscribeChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPublishSubscribeMessageChannelSpec.
- publishSubscribeChannel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPublishSubscribeMessageChannelSpec.
Q
- queueName(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Also implicitly sets the
AmqpPollableMessageChannelSpec.id(String)
(if not explicitly set). - queueName(String...) - Method in class org.springframework.integration.amqp.dsl.MessageListenerContainerSpec
-
Set the queue names.
R
- RabbitStream - Class in org.springframework.integration.amqp.dsl
-
Factory class for RabbitMQ components.
- RabbitStreamInboundChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an inbound channel adapter with a
StreamListenerContainer
. - RabbitStreamInboundChannelAdapterSpec(Environment, Codec) - Constructor for class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- RabbitStreamInboundChannelAdapterSpec(StreamListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- RabbitStreamMessageHandler - Class in org.springframework.integration.amqp.outbound
-
MessageHandler
based onRabbitStreamOperations
. - RabbitStreamMessageHandler(RabbitStreamOperations) - Constructor for class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Create an instance with the provided
RabbitStreamOperations
. - RabbitStreamMessageHandlerSpec - Class in org.springframework.integration.amqp.dsl
-
The base
MessageHandlerSpec
forRabbitStreamMessageHandler
s. - RabbitStreamMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for
StreamListenerContainer
. - rawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- receive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- receive(long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- recoverer - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- recoveryBackOff(BackOff) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Specify the
BackOff
for interval between recovery attempts. - recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a
RecoveryCallback
when using retry within the adapter. - recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a
RecoveryCallback
when using retry within the adapter. - recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- removeInterceptor(int) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- replyHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
When mapping headers for the outbound (reply) message, determine whether the headers are mapped before the message is converted, or afterwards.
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- retryOps - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a
RetryTemplate
to use for retrying a message delivery within the adapter. - retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a
RetryTemplate
to use for retrying a message delivery within the adapter. - returnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which returned messages are sent.
- ReturnedAmqpMessageException - Exception in org.springframework.integration.amqp.support
-
A MessagingException for a returned message.
- ReturnedAmqpMessageException(Message<?>, Message, int, String, String, String) - Constructor for exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- returnedMessage(ReturnedMessage) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- routingKey(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure an AMQP routing key for sending messages.
- routingKeyExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A SpEL expression to evaluate routing key at runtime.
- routingKeyExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A SpEL expression to evaluate routing key at runtime.
- routingKeyFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A function to evaluate routing key at runtime.
S
- sendFailureChannel(String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the failure channel.
- sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the failure channel.
- sendSuccessChannel(String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the success channel.
- sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the success channel.
- setAcknowledged(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- setAdviceChain(Advice[]) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an instance of AmqpAdmin for implicitly declaring Queues if the queueName is not provided.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
This is an optional reference to an AmqpAdmin to use when declaring a Queue implicitly for a PollableAmqpChannel.
- setAutoStartup(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a batching strategy to use when de-batching messages created by a batching producer (such as the BatchingRabbitTemplate).
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a batching strategy to use when de-batching messages.
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a batching strategy to use when de-batching messages.
- setBatchMode(AmqpInboundChannelAdapter.BatchMode) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
When the listener container is configured with consumerBatchEnabled, set the payload type for messages generated for the batches.
- setBatchSize(Integer) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setBeanName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setBindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set to true to bind the source message in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set to true to bind the source message in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setConfirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which acks are send (publisher confirms).
- setConfirmAckChannelName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel name to which acks are send (publisher confirms).
- setConfirmCorrelationExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- setConfirmCorrelationExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- setConfirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which nacks are send (publisher confirms).
- setConfirmNackChannelName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel name to which nacks are send (publisher confirms).
- setConfirmTimeout(long) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a timeout after which a nack will be synthesized if no publisher confirm has been received within that time.
- setConfirmTimeout(long) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the confirm timeout.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- setConsumersPerQueue(Integer) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Set the delivery mode to use if the message has no "amqp_deliveryMode" header and the message property was not set by the
MessagePropertiesConverter
. - setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the default delivery mode.
- setDefaultReplyTo(String) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
The
defaultReplyTo
address with the form - setDelay(int) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the value to set in the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - setDelayExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - setDelayExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - setEncoding(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the error message strategy to use for returned (or negatively confirmed) messages.
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
Configure the FanoutExchange instance.
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the FanoutExchange to use.
- setExchangeName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure an AMQP exchange name for sending messages.
- setExchangeNameExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure a SpEL expression to evaluate an exchange name at runtime.
- setExchangeNameExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- setExpectReply(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
Set to true if this endpoint is a gateway.
- setExposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setExtractPayload(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Set to true to extract the payload and map the headers; otherwise the entire message is converted and sent.
- setExtractPayload(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom
AmqpHeaderMapper
to replace the defaultDefaultAmqpHeaderMapper.inboundMapper()
. - setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - setHeadersLast(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
When mapping headers for the outbound message, determine whether the headers are mapped before the message is converted, or afterward.
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
When mapping headers for the outbound message, determine whether the headers are mapped before the message is converted, or afterwards.
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
When mapping headers for the outbound message, determine whether the headers are mapped before the message is converted, or afterwards.
- setInboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setLazyConnect(boolean) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set to
false
to attempt to connect during endpoint start; defaulttrue
, meaning the connection will be attempted to be established on the arrival of the first message. - setLoggingEnabled(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Specify the maximum number of subscribers supported by the channel's dispatcher (if it is an
AbstractDispatcher
). - setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Specify the
MessageConverter
to convert request and reply to/fromMessage
. - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom
MessageConverter
to replace the defaultSimpleMessageConverter
. - setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Configure a
MessageRecoverer
for retry operations. - setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Configure a
MessageRecoverer
for retry operations. - setMissingQueuesFatal(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setMultiSend(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
If true, and the message payload is an
Iterable
ofMessage
, send the messages in a single invocation of the template (same channel) and optionally wait for the confirms or die or perform all sends within a transaction (existing or new). - setOutboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setPhase(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setPrefetchCount(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setPropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom
MessagePropertiesConverter
to replace the defaultDefaultMessagePropertiesConverter
. - setPubSub(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Provide a Queue name to be used.
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an explicitly configured queue name.
- setQueueName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the Queue name to use.
- setRawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set to true to include the raw spring-amqp message as a header with key
AmqpMessageHeaderErrorMessageStrategy.AMQP_RAW_MESSAGE
, enabling callers to have access to the message to process errors. - setReceiveTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a
RecoveryCallback
when using retry within the adapter. - setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a
RecoveryCallback
when using retry within the gateway. - setRecoveryInterval(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setReplyHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
When mapping headers for the outbound (reply) message, determine whether the headers are mapped before the message is converted, or afterwards.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a
RetryTemplate
to use for retrying a message delivery within the adapter. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a
RetryTemplate
to use for retrying a message delivery within the gateway. - setReturnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which returned messages are sent.
- setReturned(ReturnedMessage) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
- setRoutingKey(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure an AMQP routing key for sending messages.
- setRoutingKeyExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- setRoutingKeyExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the failure channel.
- setSendFailureChannelName(String) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the failure channel name.
- setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the success channel.
- setSendSuccessChannelName(String) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the Success channel name.
- setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setSync(boolean) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set to true to wait for a confirmation.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setTemplateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setTransacted(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set to true to use a transacted channel for the ack.
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setWaitForConfirm(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
Set to true if you want to block the calling thread until a publisher confirm has been received.
- shouldGenerateId() - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- SimpleMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a
SimpleMessageListenerContainer
. - SimpleMessageListenerContainerSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- start() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- start() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- start() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- startConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- statefulRetryFatalWithNullMessageId(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set whether a message with a null messageId is fatal for the consumer when using stateful retry.
- stop() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- stop() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- stop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- stop(Runnable) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- stop(Runnable) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- stopConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- streamConverter(StreamMessageConverter) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Set a stream message converter.
- streamName(String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
-
Configure a name for Rabbit stream to consume from.
- subscribe(MessageHandler) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- superStream(String, String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
-
Configure a name for Rabbit super stream to consume from.
- superStream(String, String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Enable Single Active Consumer on a Super Stream.
- superStream(String, String, int) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
-
Configure a name for Rabbit super stream to consume from.
- superStream(String, String, int) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Enable Single Active Consumer on a Super Stream.
- sync(boolean) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set to true to wait for a confirmation.
T
- taskExecutor(Executor) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Configure an
Executor
used to invoke the message listener. - taskExecutor(Executor) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure an
Executor
used to invoke the message listener. - templateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure
channelTransacted
on theRabbitTemplate
used when sending messages to the channel. - toHeadersFromRequest(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- toString() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- toString() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- toString() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
- toString() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- transacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the transaction attribute to use when using an external transaction manager.
- transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure a
TransactionAttribute
to be used with theAmqpMessageChannelSpec.transactionManager(PlatformTransactionManager)
. - transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Configure a
PlatformTransactionManager
; used to synchronize the rabbit transaction with some other transaction(s). - transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure a
PlatformTransactionManager
; used to synchronize the rabbit transaction with some other transaction(s).
U
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
V
- valueOf(String) - Static method in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- waitForConfirm(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
-
Wait for a publisher confirm.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form