- AbstractAmqpChannel - Class in org.springframework.integration.amqp.channel
-
- AbstractAmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
- 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.
- 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(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- addInterceptor(int, 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(Advice...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- adviceChain - Variable in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- afterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set MessagePostProcessors that will be applied after message reception, before
invoking the MessageListener.
- 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
-
- AmqpBaseInboundChannelAdapterSpec(AmqpInboundChannelAdapter) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
- AmqpBaseInboundGatewaySpec<S extends AmqpBaseInboundGatewaySpec<S>> - Class in org.springframework.integration.amqp.dsl
-
- 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
-
- AmqpBaseOutboundEndpointSpec() - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
- 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
-
- amqpChannelFactoryBean - Variable in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
- 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 with MessageProperties.
- 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(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- AmqpInboundChannelAdapter.BatchListener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundChannelAdapter.BatchMode - Enum 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.AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl
-
- AmqpInboundChannelAdapterSpec(AbstractMessageListenerContainerSpec<?, 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(AbstractMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Construct
AmqpInboundGateway based on the provided
AbstractMessageListenerContainer
to receive request messages and
AmqpTemplate 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, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
-
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer) - 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, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
-
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer) - 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
-
- 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>> - Class in org.springframework.integration.amqp.dsl
-
- 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 the ErrorMessage.
- 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>> - Class in org.springframework.integration.amqp.dsl
-
- 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
-
- ManualAckListenerExecutionFailedException - Exception in org.springframework.integration.amqp.support
-
A ListenerExecutionFailedException enhanced with the channel and delivery tag.
- ManualAckListenerExecutionFailedException(String, Throwable, Message, Channel, long) - Constructor for exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
-
- 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, 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.
- 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 to SimpleMessageConverter.
- messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Configure the gateway's MessageConverter;
defaults to SimpleMessageConverter.
- messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
-
- 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 the
RabbitTemplate (for sends) and
SimpleMessageListenerContainer
(for receives).
- 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 of 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 of Message,
send the messages in a single invocation of the template (same channel) and optionally
wait for the confirms or die.
- 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
-
- 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(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPollableMessageChannelSpec.
- pollableChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPollableMessageChannelSpec.
- 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.
- 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.
- 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 the FanoutExchange.
- 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(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPublishSubscribeMessageChannelSpec.
- publishSubscribeChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpPublishSubscribeMessageChannelSpec.
- 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.
- 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
(exchange)/(routingKey)
- 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
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- 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 afterwards.
- 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.
- 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;
default true, 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.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/from Message.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom MessageConverter to replace the default
SimpleMessageConverter.
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- 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 of Message, 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 default
DefaultMessagePropertiesConverter.
- 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
-
- 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.
- setReturnedMessage(Message) - 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
-
- setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- 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.
- 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.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.config.AmqpChannelFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- stop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- stopConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-