Skip navigation links
Spring Integration
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

A

AbstractAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
Base class for MessageGroupProcessor implementations that aggregate the group of Messages into a single Message.
AbstractAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
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
 
AbstractBatchingMessageGroupStore - Class in org.springframework.integration.store
 
AbstractBatchingMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
AbstractByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
Base class for (de)serializers that provide a mechanism to reconstruct a byte array from an arbitrary stream.
AbstractByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
AbstractCandidate - Class in org.springframework.integration.leader
Base implementation of a Candidate.
AbstractCandidate() - Constructor for class org.springframework.integration.leader.AbstractCandidate
Instantiate a abstract candidate.
AbstractCandidate(String, String) - Constructor for class org.springframework.integration.leader.AbstractCandidate
Instantiate a abstract candidate.
AbstractChannelAdapterParser - Class in org.springframework.integration.config.xml
Base parser for Channel Adapters.
AbstractChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
AbstractChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
AbstractChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
AbstractChannelParser - Class in org.springframework.integration.config.xml
Base class for channel parsers.
AbstractChannelParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelParser
 
AbstractClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Abstract class for client connection factories; client connection factories establish outgoing connections.
AbstractClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Constructs a factory that will established connections to the host and port.
AbstractConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
The abstract MongoDB AbstractMessageGroupStore implementation to provide configuration for common options for implementations of this class.
AbstractConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
AbstractConfigurableMongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
AbstractConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
AbstractConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Base class for all connection factories.
AbstractConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
AbstractConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
AbstractConnectionFactorySpec<S extends AbstractConnectionFactorySpec<S,C>,C extends AbstractConnectionFactory> - Class in org.springframework.integration.ip.dsl
AbstractConnectionFactorySpec(C) - Constructor for class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
AbstractConsumerEndpointParser - Class in org.springframework.integration.config.xml
Base class parser for elements that create Message Endpoints.
AbstractConsumerEndpointParser() - Constructor for class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
AbstractCorrelatingMessageHandler - Class in org.springframework.integration.aggregator
Abstract Message handler that holds a buffer of correlated messages in a MessageStore.
AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
AbstractCorrelatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup - Class in org.springframework.integration.aggregator
 
AbstractCorrelatingMessageHandlerParser - Class in org.springframework.integration.config.xml
Base class for parsers that create an instance of AbstractCorrelatingMessageHandler.
AbstractCorrelatingMessageHandlerParser() - Constructor for class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
 
AbstractDirectoryAwareFileListFilter<F> - Class in org.springframework.integration.file.filters
A file list filter that can be configured to always accept (pass) directories.
AbstractDirectoryAwareFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
 
AbstractDispatcher - Class in org.springframework.integration.dispatcher
Base class for MessageDispatcher implementations.
AbstractDispatcher() - Constructor for class org.springframework.integration.dispatcher.AbstractDispatcher
 
AbstractEndpoint - Class in org.springframework.integration.endpoint
The base class for Message Endpoint implementations.
AbstractEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractEndpoint
 
AbstractEvaluationContextFactoryBean - Class in org.springframework.integration.config
Abstract class for integration evaluation context factory beans.
AbstractEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
AbstractExecutorChannel - Class in org.springframework.integration.channel
The AbstractSubscribableChannel base implementation for those inheritors which logic may be based on the Executor.
AbstractExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel
 
AbstractExecutorChannel.MessageHandlingTask - Class in org.springframework.integration.channel
 
AbstractExpressionEvaluator - Class in org.springframework.integration.util
 
AbstractExpressionEvaluator() - Constructor for class org.springframework.integration.util.AbstractExpressionEvaluator
 
AbstractFetchLimitingMessageSource<T> - Class in org.springframework.integration.endpoint
A message source that can limit the number of remote objects it fetches.
AbstractFetchLimitingMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
 
AbstractFileInfo<F> - Class in org.springframework.integration.file.remote
Abstract implementation of FileInfo; provides a setter for the remote directory and a generic toString implementation.
AbstractFileInfo() - Constructor for class org.springframework.integration.file.remote.AbstractFileInfo
 
AbstractFileListFilter<F> - Class in org.springframework.integration.file.filters
A convenience base class for any FileListFilter whose criteria can be evaluated against each File in isolation.
AbstractFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractFileListFilter
 
AbstractFileLockerFilter - Class in org.springframework.integration.file.locking
Convenience base class for implementing FileLockers that check a lock before accepting a file.
AbstractFileLockerFilter() - Constructor for class org.springframework.integration.file.locking.AbstractFileLockerFilter
 
AbstractFilePayloadTransformer<T> - Class in org.springframework.integration.file.transformer
Base class for transformers that convert a File payload.
AbstractFilePayloadTransformer() - Constructor for class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
AbstractFilePayloadTransformerParser - Class in org.springframework.integration.file.config
Base class for File payload transformer parsers.
AbstractFilePayloadTransformerParser() - Constructor for class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
 
AbstractFtpSessionFactory<T extends org.apache.commons.net.ftp.FTPClient> - Class in org.springframework.integration.ftp.session
Base class for FTP SessionFactory implementations.
AbstractFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
AbstractHandleMessageAdvice - Class in org.springframework.integration.handler.advice
The base HandleMessageAdvice for advices which can be applied only for the MessageHandler.handleMessage(Message).
AbstractHandleMessageAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
Abstract base class for RequestReplyHeaderMapper implementations.
AbstractHeaderMapper(String, Collection<String>, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper
Create a new instance.
AbstractHeaderMapper.CompositeHeaderMatcher - Class in org.springframework.integration.mapping
A composite AbstractHeaderMapper.HeaderMatcher that matches if one of provided AbstractHeaderMapper.HeaderMatchers matches to the headerName.
AbstractHeaderMapper.ContentBasedHeaderMatcher - Class in org.springframework.integration.mapping
A content-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header is contained within a list of candidates.
AbstractHeaderMapper.HeaderMatcher - Interface in org.springframework.integration.mapping
Strategy interface to determine if a given header name matches.
AbstractHeaderMapper.PatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
A pattern-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header matches one of the specified simple patterns.
AbstractHeaderMapper.PrefixBasedMatcher - Class in org.springframework.integration.mapping
A prefix-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header starts with a configurable prefix.
AbstractHeaderMapper.SinglePatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
A pattern-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header matches the specified simple pattern.
AbstractHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
AbstractHeaderValueMessageProcessor() - Constructor for class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
AbstractHttpRequestExecutingMessageHandler - Class in org.springframework.integration.http.outbound
Base class for http outbound adapter/gateway.
AbstractHttpRequestExecutingMessageHandler(Expression) - Constructor for class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
AbstractInboundFileSynchronizer<F> - Class in org.springframework.integration.file.remote.synchronizer
Base class charged with knowing how to connect to a remote file system, scan it for new files and then download the files.
AbstractInboundFileSynchronizer(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Create a synchronizer with the SessionFactory used to acquire Session instances.
AbstractInboundFileSynchronizingMessageSource<F> - Class in org.springframework.integration.file.remote.synchronizer
Factors out the common logic between the FTP and SFTP adapters.
AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>, Comparator<File>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
AbstractInboundGatewayParser - Class in org.springframework.integration.config.xml
Base class for inbound gateway parsers.
AbstractInboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
AbstractIntegrationMessageBuilder<T> - Class in org.springframework.integration.support
 
AbstractIntegrationMessageBuilder() - Constructor for class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
AbstractIntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
Base class for NamespaceHandlers that registers a BeanFactoryPostProcessor for configuring default bean definitions.
AbstractIntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
AbstractInternetProtocolReceivingChannelAdapter - Class in org.springframework.integration.ip
Base class for inbound TCP/UDP Channel Adapters.
AbstractInternetProtocolReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
AbstractInternetProtocolSendingMessageHandler - Class in org.springframework.integration.ip
Base class for UDP MessageHandlers.
AbstractInternetProtocolSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
AbstractJacksonJsonObjectMapper<N,P,J> - Class in org.springframework.integration.support.json
Base class for Jackson JsonObjectMapper implementations.
AbstractJacksonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
AbstractJmsChannel - Class in org.springframework.integration.jms
 
AbstractJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.AbstractJmsChannel
 
AbstractJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
The Abstract Parser for the JPA Outbound Gateways.
AbstractJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
 
AbstractJsonInboundMessageMapper<P> - Class in org.springframework.integration.support.json
Abstract InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.
AbstractJsonInboundMessageMapper(Type) - Constructor for class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
AbstractKafkaChannel - Class in org.springframework.integration.kafka.channel
Abstract MessageChannel backed by a Kafka topic.
AbstractKafkaChannel(KafkaOperations<?, ?>, String) - Constructor for class org.springframework.integration.kafka.channel.AbstractKafkaChannel
Construct an instance with the provided paramters.
AbstractKafkaChannelSpec<S extends AbstractKafkaChannelSpec<S,C>,C extends AbstractKafkaChannel> - Class in org.springframework.integration.kafka.dsl
Spec for a message channel backed by a Kafka topic.
AbstractKafkaChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 
AbstractKeyValueMessageStore - Class in org.springframework.integration.store
Base class for implementations of Key/Value style MessageGroupStore and MessageStore
AbstractKeyValueMessageStore() - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
 
AbstractKeyValueMessageStore(String) - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
Construct an instance based on the provided prefix for keys to distinguish between different store instances in the same target key-value data base.
AbstractKryoCodec - Class in org.springframework.integration.codec.kryo
Base class for Codecs using Kryo.
AbstractKryoCodec() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
AbstractKryoRegistrar - Class in org.springframework.integration.codec.kryo
Base class for KryoRegistrar implementations.
AbstractKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
AbstractLeaderEvent - Class in org.springframework.integration.leader.event
Base ApplicationEvent class for leader based events.
AbstractLeaderEvent(Object) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
Create a new ApplicationEvent.
AbstractLeaderEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
Create a new ApplicationEvent.
AbstractMailMessageTransformer<T> - Class in org.springframework.integration.mail.transformer
Base class for Transformers that convert from a JavaMail Message to a Spring Integration Message.
AbstractMailMessageTransformer() - Constructor for class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
AbstractMailReceiver - Class in org.springframework.integration.mail
Base class for MailReceiver implementations.
AbstractMailReceiver() - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
 
AbstractMailReceiver(URLName) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
 
AbstractMailReceiver(String) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
 
AbstractMappingMessageRouter - Class in org.springframework.integration.router
Base class for all Message Routers that support mapping from arbitrary String values to Message Channel names.
AbstractMappingMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMappingMessageRouter
 
AbstractMarkerFilePresentFileListFilter<F> - Class in org.springframework.integration.file.filters
A FileListFilter that only passes files matched by one or more FileListFilter if a corresponding marker file is also present to indicate a file transfer is complete.
AbstractMarkerFilePresentFileListFilter(FileListFilter<F>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Construct an instance with a single FileListFilter and ".complete" will be appended to the name of a matched file when looking for the marker file.
AbstractMarkerFilePresentFileListFilter(FileListFilter<F>, String) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Construct an instance with a single FileListFilter and a suffix that will will be appended to the name of a matched file when looking for the marker file.
AbstractMarkerFilePresentFileListFilter(FileListFilter<F>, Function<String, String>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Construct an instance with a single FileListFilter and a function that will be applied to the name of a matched file when looking for the marker file.
AbstractMarkerFilePresentFileListFilter(Map<FileListFilter<F>, Function<String, String>>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Construct an instance with a map of FileListFilter and functions be applied to the name of a matched file when looking for the marker file.
AbstractMessageChannel - Class in org.springframework.integration.channel
Base class for MessageChannel implementations providing common properties such as the channel name.
AbstractMessageChannel() - Constructor for class org.springframework.integration.channel.AbstractMessageChannel
 
AbstractMessageChannel.ChannelInterceptorList - Class in org.springframework.integration.channel
A convenience wrapper class for the list of ChannelInterceptors.
AbstractMessageGroupStore - Class in org.springframework.integration.store
 
AbstractMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
 
AbstractMessageGroupStore(boolean) - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
 
AbstractMessageHandler - Class in org.springframework.integration.handler
Base class for MessageHandler implementations.
AbstractMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageHandler
 
AbstractMessageListenerContainerSpec<S extends AbstractMessageListenerContainerSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl
Base class for container specs.
AbstractMessageListenerContainerSpec(C) - Constructor for class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
AbstractMessageProcessingSelector - Class in org.springframework.integration.filter
A base class for MessageSelector implementations that delegate to a MessageProcessor.
AbstractMessageProcessingSelector(MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
AbstractMessageProcessingTransformer - Class in org.springframework.integration.transformer
Base class for Message Transformers that delegate to a MessageProcessor.
AbstractMessageProcessingTransformer(MessageProcessor<?>) - Constructor for class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
AbstractMessageProcessor<T> - Class in org.springframework.integration.handler
 
AbstractMessageProcessor() - Constructor for class org.springframework.integration.handler.AbstractMessageProcessor
 
AbstractMessageProducingHandler - Class in org.springframework.integration.handler
The base AbstractMessageHandler implementation for the MessageProducer.
AbstractMessageProducingHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageProducingHandler
 
AbstractMessageRouter - Class in org.springframework.integration.router
Base class for all Message Routers.
AbstractMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMessageRouter
 
AbstractMessageSource<T> - Class in org.springframework.integration.endpoint
Abstract message source.
AbstractMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractMessageSource
 
AbstractMessageSourceAdvice - Class in org.springframework.integration.aop
Deprecated.
since 5.3 in favor of MessageSourceMutator.
AbstractMessageSourceAdvice() - Constructor for class org.springframework.integration.aop.AbstractMessageSourceAdvice
Deprecated.
 
AbstractMessageSplitter - Class in org.springframework.integration.splitter
Base class for Message-splitting handlers.
AbstractMessageSplitter() - Constructor for class org.springframework.integration.splitter.AbstractMessageSplitter
 
AbstractMeter(MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
 
AbstractMethodAnnotationPostProcessor<T extends Annotation> - Class in org.springframework.integration.config.annotation
Base class for Method-level annotation post-processors.
AbstractMethodAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
AbstractMqttMessageDrivenChannelAdapter - Class in org.springframework.integration.mqtt.inbound
Abstract class for MQTT Message-Driven Channel Adapters.
AbstractMqttMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
AbstractMqttMessageHandler - Class in org.springframework.integration.mqtt.outbound
Abstract class for MQTT outbound channel adapters.
AbstractMqttMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
AbstractOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Base class for outbound Channel Adapter parsers.
AbstractOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
 
AbstractOutboundGatewayParser - Class in org.springframework.integration.config.xml
Base class for url-based outbound gateway parsers.
AbstractOutboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
AbstractPayloadTransformer<T,U> - Class in org.springframework.integration.transformer
A base class for Transformer implementations that modify the payload of a Message.
AbstractPayloadTransformer() - Constructor for class org.springframework.integration.transformer.AbstractPayloadTransformer
 
AbstractPersistentAcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
Stores "seen" files in a MetadataStore to survive application restarts.
AbstractPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
AbstractPollableChannel - Class in org.springframework.integration.channel
Base class for all pollable channels.
AbstractPollableChannel() - Constructor for class org.springframework.integration.channel.AbstractPollableChannel
 
AbstractPollingEndpoint - Class in org.springframework.integration.endpoint
 
AbstractPollingEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
AbstractPollingInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Base parser for inbound Channel Adapters that poll a source.
AbstractPollingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
 
AbstractPooledBufferByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
Base class for deserializers that cannot determine the buffer size needed.
AbstractPooledBufferByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
 
AbstractReactiveMessageHandler - Class in org.springframework.integration.handler
Base class for ReactiveMessageHandler implementations.
AbstractReactiveMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReactiveMessageHandler
 
AbstractRegexPatternFileListFilter<F> - Class in org.springframework.integration.file.filters
Filters a listing of files by qualifying their 'name' against a regular expression (an instance of Pattern)
AbstractRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
AbstractRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
AbstractRemoteFileInboundChannelAdapterParser - Class in org.springframework.integration.file.config
Abstract base class for parsing remote file inbound channel adapters.
AbstractRemoteFileInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
AbstractRemoteFileOutboundGateway<F> - Class in org.springframework.integration.file.remote.gateway
Base class for Outbound Gateways that perform remote file operations.
AbstractRemoteFileOutboundGateway(SessionFactory<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance using the provided session factory and callback for performing operations on the session.
AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance with the supplied remote file template and callback for performing operations on the session.
AbstractRemoteFileOutboundGateway(SessionFactory<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
AbstractRemoteFileOutboundGateway(SessionFactory<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
AbstractRemoteFileOutboundGateway.Command - Enum in org.springframework.integration.file.remote.gateway
Enumeration of commands supported by the gateways.
AbstractRemoteFileOutboundGateway.Option - Enum in org.springframework.integration.file.remote.gateway
Enumeration of options supported by various commands.
AbstractRemoteFileOutboundGatewayParser - Class in org.springframework.integration.file.config
 
AbstractRemoteFileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
AbstractRemoteFileStreamingInboundChannelAdapterParser - Class in org.springframework.integration.file.config
Abstract base class for parsing remote file streaming inbound channel adapters.
AbstractRemoteFileStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
AbstractRemoteFileStreamingMessageSource<F> - Class in org.springframework.integration.file.remote
A message source that produces a message with an InputStream payload referencing a remote file.
AbstractRemoteFileStreamingMessageSource(RemoteFileTemplate<F>, Comparator<F>) - Constructor for class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
AbstractReplyProducingMessageHandler - Class in org.springframework.integration.handler
Base class for MessageHandlers that are capable of producing replies.
AbstractReplyProducingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
AbstractReplyProducingMessageHandler.RequestHandler - Interface in org.springframework.integration.handler
An implementation of this interface is used to wrap the AbstractReplyProducingMessageHandler.handleRequestMessage(Message) method.
AbstractReplyProducingPostProcessingMessageHandler - Class in org.springframework.integration.handler
 
AbstractReplyProducingPostProcessingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
AbstractRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
Base class for MessageHandler advice classes.
AbstractRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
 
AbstractRequestHandlerAdvice.ExecutionCallback - Interface in org.springframework.integration.handler.advice
Called by subclasses in doInvoke() to proceed() the invocation.
AbstractRequestHandlerAdvice.ThrowableHolderException - Exception in org.springframework.integration.handler.advice
 
AbstractRequestResponseScenarioTests - Class in org.springframework.integration.test.support
Convenience class for testing Spring Integration request-response message scenarios.
AbstractRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
 
AbstractResponseValidator<T> - Class in org.springframework.integration.test.support
The base class for response validators used for RequestResponseScenarios
AbstractResponseValidator() - Constructor for class org.springframework.integration.test.support.AbstractResponseValidator
 
AbstractRouterParser - Class in org.springframework.integration.config.xml
Base parser for routers.
AbstractRouterParser() - Constructor for class org.springframework.integration.config.xml.AbstractRouterParser
 
AbstractRouterSpec<S extends AbstractRouterSpec<S,R>,R extends AbstractMessageRouter> - Class in org.springframework.integration.dsl
AbstractRouterSpec(R) - Constructor for class org.springframework.integration.dsl.AbstractRouterSpec
 
AbstractRSocketConnector - Class in org.springframework.integration.rsocket
A base connector container for common RSocket client and server functionality.
AbstractRSocketConnector(IntegrationRSocketMessageHandler) - Constructor for class org.springframework.integration.rsocket.AbstractRSocketConnector
 
AbstractScriptExecutingMessageProcessor<T> - Class in org.springframework.integration.scripting
Base MessageProcessor for scripting implementations to extend.
AbstractScriptExecutingMessageProcessor() - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
AbstractScriptExecutingMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
AbstractScriptExecutor - Class in org.springframework.integration.scripting.jsr223
Base Class for ScriptExecutor.
AbstractScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
AbstractScriptExecutor(ScriptEngine) - Constructor for class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
AbstractScriptParser - Class in org.springframework.integration.scripting.config
 
AbstractScriptParser() - Constructor for class org.springframework.integration.scripting.config.AbstractScriptParser
 
AbstractServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Base class for all server connection factories.
AbstractServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
The port on which the factory will listen.
AbstractSimpleMessageHandlerFactoryBean<H extends MessageHandler> - Class in org.springframework.integration.config
Factory bean to create and configure a MessageHandler.
AbstractSimpleMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
AbstractSimplePatternFileListFilter<F> - Class in org.springframework.integration.file.filters
Base class for filters that support ant style path expressions, which are less powerful but more readable than regular expressions.
AbstractSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
 
AbstractStandardMessageHandlerFactoryBean - Class in org.springframework.integration.config
Base class for FactoryBeans that create standard MessageHandler instances.
AbstractStandardMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
AbstractStompSessionManager - Class in org.springframework.integration.stomp
Base StompSessionManager implementation to manage a single StompSession over its ListenableFuture from the target implementation of this class.
AbstractStompSessionManager(StompClientSupport) - Constructor for class org.springframework.integration.stomp.AbstractStompSessionManager
 
AbstractSubscribableChannel - Class in org.springframework.integration.channel
Base implementation of MessageChannel that invokes the subscribed handler(s) by delegating to a MessageDispatcher.
AbstractSubscribableChannel() - Constructor for class org.springframework.integration.channel.AbstractSubscribableChannel
 
AbstractTcpConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
Base class for TCP Connection Support implementations.
AbstractTcpConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
 
AbstractTransformer - Class in org.springframework.integration.transformer
A base class for Transformer implementations.
AbstractTransformer() - Constructor for class org.springframework.integration.transformer.AbstractTransformer
 
AbstractTransformerParser - Class in org.springframework.integration.config.xml
 
AbstractTransformerParser() - Constructor for class org.springframework.integration.config.xml.AbstractTransformerParser
 
AbstractUdpOutboundChannelAdapterSpec<S extends AbstractUdpOutboundChannelAdapterSpec<S>> - Class in org.springframework.integration.ip.dsl
AbstractUdpOutboundChannelAdapterSpec() - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
AbstractUdpOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
AbstractUdpOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
AbstractUdpOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
AbstractWebServiceInboundGateway - Class in org.springframework.integration.ws
 
AbstractWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
AbstractWebServiceOutboundGateway - Class in org.springframework.integration.ws
Base class for outbound Web Service-invoking Messaging Gateways.
AbstractWebServiceOutboundGateway(String, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
AbstractWebServiceOutboundGateway(DestinationProvider, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
AbstractWebServiceOutboundGateway.RequestMessageCallback - Class in org.springframework.integration.ws
 
AbstractWebServiceOutboundGateway.ResponseMessageExtractor - Class in org.springframework.integration.ws
 
AbstractXmlTransformer - Class in org.springframework.integration.xml.transformer
super class for XmlTransformer
AbstractXmlTransformer() - Constructor for class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
AbstractXmppConnectionAwareEndpoint - Class in org.springframework.integration.xmpp.core
 
AbstractXmppConnectionAwareEndpoint() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
AbstractXmppConnectionAwareEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
AbstractXmppConnectionAwareMessageHandler - Class in org.springframework.integration.xmpp.core
 
AbstractXmppConnectionAwareMessageHandler() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
AbstractXmppConnectionAwareMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
AbstractXmppInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Base class for XMPP inbound parsers
AbstractXmppInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
AbstractXmppOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Base class of XMPP outbound parsers
AbstractXmppOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
 
AbstractXPathMessageSelector - Class in org.springframework.integration.xml.selector
Base class for XPath MessageSelector implementations.
AbstractXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
AbstractXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
AbstractXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
AbstractXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
accept(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
ACCEPT the associated message if the callback is not null.
accept(S) - Method in interface org.springframework.integration.core.GenericSelector
 
accept(Message<?>) - Method in interface org.springframework.integration.core.MessageSelector
 
accept(F) - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
Subclasses must implement this method.
accept(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
Accepts the given file if its name matches the pattern.
accept(F) - Method in class org.springframework.integration.file.filters.AcceptAllFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.ChainFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
accept(F) - Method in class org.springframework.integration.file.filters.ExpressionFileListFilter
 
accept(F) - Method in interface org.springframework.integration.file.filters.FileListFilter
Filter a single file; only called externally if FileListFilter.supportsSingleFileFiltering() returns true.
accept(File) - Method in class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
 
accept(File) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
accept(File) - Method in class org.springframework.integration.file.locking.AbstractFileLockerFilter
 
accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
accept(ObjectName, String) - Method in class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
 
accept(ObjectName, String) - Method in interface org.springframework.integration.jmx.MBeanAttributeFilter
 
accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NamedFieldsMBeanAttributeFilter
 
accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NotNamedFieldsMBeanAttributeFilter
 
accept(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
accept(Message<?>) - Method in class org.springframework.integration.selector.MessageSelectorChain
Pass the message through the selector chain.
accept(Message<?>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
 
accept(Message<?>) - Method in class org.springframework.integration.selector.PayloadTypeSelector
 
accept(Message<?>) - Method in class org.springframework.integration.selector.UnexpiredMessageSelector
 
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Return true if the XPathExpression evaluates to true
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Evaluate the payload and return true if the value returned by the XPathExpression matches the regex.
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Evaluate the payload and return true if the value returned by the XPathExpression is equal to the valueToTestFor.
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
AcceptAllFileListFilter<F> - Class in org.springframework.integration.file.filters
Simple implementation of FileListFilter that always returns true.
AcceptAllFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptAllFileListFilter
 
acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.integration.util.JavaUtils
Invoke Consumer.accept(Object) with the value if the condition is true.
acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.util.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the condition is true.
acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.integration.util.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.integration.util.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the value argument is not null or empty.
acceptIfNotEmpty(List<T>, Consumer<List<T>>) - Method in class org.springframework.integration.util.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfNotEmpty(T[], Consumer<T[]>) - Method in class org.springframework.integration.util.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.integration.util.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null.
acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.util.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the t2 argument is not null.
acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
AcceptOnceCollectionFilter<T> - Class in org.springframework.integration.util
An implementation of CollectionFilter that remembers the elements passed in the previous invocation in order to avoid returning those elements more than once.
AcceptOnceCollectionFilter() - Constructor for class org.springframework.integration.util.AcceptOnceCollectionFilter
 
AcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
FileListFilter that passes files only one time.
AcceptOnceFileListFilter(int) - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
Creates an AcceptOnceFileListFilter that is based on a bounded queue.
AcceptOnceFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
Creates an AcceptOnceFileListFilter based on an unbounded queue.
ACK - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
ACK_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The remote ip address to which UDP application-level acks will be sent.
ACK_ID - Static variable in class org.springframework.integration.ip.IpHeaders
A correlation id for UDP application-level acks.
ackCount(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the number of outstanding record count after which offsets should be committed when ContainerProperties.AckMode#COUNT or ContainerProperties.AckMode#COUNT_TIME is being used.
ackCounter(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
ackDiscarded(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
A boolean flag to indicate if FilteringMessageListenerAdapter should acknowledge discarded records or not.
ackMode(ContainerProperties.AckMode) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the ack mode to use when auto ack (in the configuration properties) is false.
acknowledge(AcknowledgmentCallback.Status) - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
Acknowledge the message.
acknowledge() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
 
acknowledge() - Method in interface org.springframework.integration.acks.SimpleAcknowledgment
Acknowledge the message delivery.
acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
acknowledge() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
ACKNOWLEDGMENT_CALLBACK - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
A callback to acknowledge message delivery.
AcknowledgmentCallback - Interface in org.springframework.integration.acks
A general abstraction over acknowledgments.
AcknowledgmentCallback.Status - Enum in org.springframework.integration.acks
 
AcknowledgmentCallbackFactory<T> - Interface in org.springframework.integration.acks
A factory for creating AcknowledgmentCallbacks.
ackOnError(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Deprecated.
in favor of GenericErrorHandler.isAckAfterHandle().
ackTime(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the time (ms) after which outstanding offsets should be committed when ContainerProperties.AckMode#TIME or ContainerProperties.AckMode#COUNT_TIME is being used.
ackTimeout(long) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
 
AckUtils - Class in org.springframework.integration.acks
Utility methods for acting on AcknowledgmentCallback headers.
acquire(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
acquire(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
activeCount - Variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
ACTUAL_CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
For information only - when using a cached or failover client connection factory, contains the actual underlying connection id.
add(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
add(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
add(String, PropertyAccessor) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Add the provided named property accessor.
add(PropertyAccessor...) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Add the provided property accessors.
add(Properties) - Method in class org.springframework.integration.history.MessageHistory
 
add(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
 
add(MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
Add a selector to the end of the chain.
add(int, MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
Add a selector to the chain at the specified index.
add(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
Add the message to this group.
add(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
addAll(Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
 
addAll(int, Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
 
addAllowedPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addAllowedPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addAllowedPatterns(String...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addAllowedPatterns(String...) - Method in class org.springframework.integration.mongodb.support.BinaryToMessageConverter
Add patterns for packages/classes that are allowed to be deserialized.
addAllowedPatterns(String...) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
Add package/class patterns to the allow list.
addAttribute(String, Object) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
Adds attribute to this ResourceHolder instance
addBean(Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Add an object which will be registered as an IntegrationFlow dependant bean in the application context.
addBean(String, Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Add an object which will be registered as an IntegrationFlow dependant bean in the application context.
addBean(Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
Add an object which will be registered as an IntegrationFlow dependant bean in the application context.
addBean(String, Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
Add an object which will be registered as an IntegrationFlow dependant bean in the application context.
addComponent(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
addComponent(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
addComponents(Map<Object, String>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
addConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
addConstructorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
Adds a constructor-arg to the provided bean definition builder with the value of the attribute whose name is provided if that attribute is defined in the given element.
addCustomHeaders(TcpConnection, MessageHeaders) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
addDelayProperty(Message<?>, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
addDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
Add a destination (or destinations) to the subscribed list and subscribe it.
addDestinationConfigToConstructor(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
Adds destination configuration to constructor.
addDiscardCallback(Consumer<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
addDiscardCallback(Consumer<F>) - Method in interface org.springframework.integration.file.filters.DiscardAwareFileListFilter
 
addDiscardCallback(Consumer<File>) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
addElementToHeaderMapping(String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
addElementToHeaderMapping(String, String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
addEndpoint(IntegrationRSocketEndpoint) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
Add an IntegrationRSocketEndpoint for mapping and handling RSocket requests.
addFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
addFilters(FileListFilter<F>...) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
addFilters(Collection<? extends FileListFilter<F>>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
Not thread safe.
addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Add the handler to the internal Set.
addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
Add a message handler.
addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.file.splitter.FileSplitter
 
addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Allows subclasses to add extra headers to the output messages.
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Add a channel interceptor to the end of the list.
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Add a channel interceptor to the specified index of the list.
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
addLifecyclesToRole(String, List<String>) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle beans to the role using their names.
addLifecycleToRole(String, SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle to the role.
addLifecycleToRole(String, String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle bean to the role using its name.
addListener(MetadataStoreListener) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
addListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
Registers a listener with the metadata store
addListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
addMatchingInterceptors(InterceptableChannel, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
Add any interceptor whose pattern matches against the channel's name.
addMessage(Message<T>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
addMessage(Message<T>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
addMessage(Message<T>) - Method in interface org.springframework.integration.store.MessageStore
Put the provided Message into the MessageStore.
addMessage(Message<T>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
addMessageDocument(MessageDocument) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
addMessagesToGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
Store messages with an association to a group id.
addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.SimpleMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Store a message in the database.
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
addMessageToGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Store a message with an association to a group id.
addMessagingAnnotationPostProcessor(Class<A>, MethodAnnotationPostProcessor<A>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
addNewConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
When we are using sockets owned by a TcpListener, this method is called each time a new connection is made.
addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Add header patterns ("xxx*", "*xxx", "*xxx*" or "xxx*yyy") that will NOT be copied from the inbound message if AbstractMessageProducingHandler.shouldCopyRequestHeaders() is true, instead of overwriting the existing set.
addNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Add headers that will NOT be copied from the inbound message if the handler is configured to copy headers, instead of overwriting the existing set.
addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
addPatternMapping(Pattern, ChannelAccessPolicy) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
addProperties(Map<String, Object>) - Method in class org.springframework.integration.graph.IntegrationNode
Add extra property to the node.
addProperty(String, Object) - Method in class org.springframework.integration.graph.IntegrationNode
Add extra property to the node.
addQueueNames(String...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
addQueues(Queue...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
addReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
Add headers to the configured list of read only headers.
addRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
 
addRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
 
addRecipient(String, MessageSelector) - Method in class org.springframework.integration.router.RecipientListRouter
 
addRecipient(MessageChannel) - Method in class org.springframework.integration.router.RecipientListRouter
 
addRecipient(MessageChannel, MessageSelector) - Method in class org.springframework.integration.router.RecipientListRouter
 
addRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Add a recipient with channelName and expression.
addRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Add a recipient with channelName.
addSessionFactory(String, SessionFactory<F>) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
addSessionFactory(Object, SessionFactory<F>) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
Add a session factory.
addStandardHeaders(TcpConnection, MessageHeaders) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
addSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
Add a topic to the subscribed list.
addTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
Add a topic (or topics) to the subscribed list (qos=1).
addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
addTopics(String[], int[]) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
Add topics to the subscribed list.
adjustLogLevels(String, List<Class<?>>, List<String>, Level) - Static method in class org.springframework.integration.test.util.TestUtils
 
advice(Advice...) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
advice(Advice...) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Configure a list of Advice objects to be applied, in nested order, to the endpoint's handler.
advice(Advice...) - Method in class org.springframework.integration.dsl.PollerSpec
Specify AOP Advices for the pollingTask.
adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
adviceChain - Variable in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
adviceChain - Variable in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
adviceChain(Advice...) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Configure a chain of Advice objects for message delivery, applied to the downstream flow.
AdviceMessage<T> - Class in org.springframework.integration.message
A message implementation that is produced by an advice after successful message handling.
AdviceMessage(T, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
 
AdviceMessage(T, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
 
AdviceMessage(T, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
A constructor with the MessageHeaders instance to use.
AdviceMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the AdviceMessage.
AdviceMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
 
afterAll(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
 
afterCommit(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
afterCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
 
afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
 
afterPropertiesSet() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
afterPropertiesSet() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
afterPropertiesSet() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
afterPropertiesSet() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
afterPropertiesSet() - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
afterPropertiesSet() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Verifies parameters, sets the parameters on SimpleJdbcCallOperations and ensures the appropriate SqlParameterSourceFactory is defined when ProcedureParameter are passed in.
afterPropertiesSet() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
afterPropertiesSet() - Method in class org.springframework.integration.jpa.core.JpaExecutor
Verify and sets the parameters.
afterPropertiesSet() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
afterPropertiesSet() - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
afterPropertiesSet() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
afterPropertiesSet() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
afterPropertiesSet() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
afterPropertiesSet() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
 
afterPropertiesSet() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
afterPropertiesSet() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
afterPropertiesSet() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
afterPropertiesSet() - Method in class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
 
afterPropertiesSet() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
afterPropertiesSet() - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
afterPropertiesSet() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
afterPropertiesSet() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
Deprecated.
afterReceive(Message<?>, Object) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
 
afterReceive(Message<?>, Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
 
afterReceive(Message<?>, MessageSource<?>) - Method in interface org.springframework.integration.aop.MessageSourceMutator
Subclasses can take actions based on the result of the poll; e.g.
afterReceive(Message<?>, Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
Subclasses can take actions based on the result of the Joinpoint.proceed(); e.g.
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Deprecated.
 
afterReceive(Message<?>, Object) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
 
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
 
afterReceive(boolean, MessageSource<?>) - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
Invoked after the message source receive() method.
afterReceive(boolean, MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
afterReceiveCompletion(Message<?>, MessageChannel, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
afterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Set MessagePostProcessors that will be applied after message reception, before invoking the MessageListener.
afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Allows you to provide additional logic that needs to be performed after the MessageGroup was released.
afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Subclasses may override if special action is needed because the group was released or discarded due to a timeout.
afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
Complete the group and remove all its messages.
afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
Perform group removal if its size is equal to the sequenceSize.
afterRollback(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
afterRollback(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterRollback(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterRollback(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterRollback(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
afterSendCompletion(Message<?>, MessageChannel, boolean, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
afterSessionEnded(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
afterSessionEnded(WebSocketSession, CloseStatus, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
afterSessionEnded(WebSocketSession, CloseStatus) - Method in interface org.springframework.integration.websocket.WebSocketListener
Invoked after a WebSocketSession has ended.
afterSessionStarted(WebSocketSession) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
afterSessionStarted(WebSocketSession, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
afterSessionStarted(WebSocketSession) - Method in interface org.springframework.integration.websocket.WebSocketListener
Invoked after a WebSocketSession has started.
afterShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
 
afterShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
Called after normal shutdown of schedulers, executors etc, and after the shutdown delay has elapsed, but before any forced shutdown of any remaining active scheduler/executor threads.Can optionally return the number of active messages still in process.
afterShutdown() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
afterShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
afterShutdown() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
afterShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
afterShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
aggregate() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the AggregatingMessageHandler with default options.
aggregate(Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the AggregatingMessageHandler with provided options from AggregatorSpec.
AggregatedXmlMessageValidationException - Exception in org.springframework.integration.xml
 
AggregatedXmlMessageValidationException(List<Throwable>) - Constructor for exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
aggregateHeaders(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
This default implementation simply returns all headers that have no conflicts among the group.
AggregateMessageDeliveryException - Exception in org.springframework.integration.dispatcher
An Exception that encapsulates an aggregated group of Exceptions for use by dispatchers that may try multiple handler invocations within a single dispatch operation.
AggregateMessageDeliveryException(Message<?>, String, List<? extends Exception>) - Constructor for exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
Evaluate the expression provided on the messages (a collection) in the group, and delegate to the MessagingTemplate to send downstream.
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
AggregatingMessageHandler - Class in org.springframework.integration.aggregator
Aggregator specific implementation of AbstractCorrelatingMessageHandler.
AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
AggregatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
Aggregator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of aggregating messages.
AggregatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @Aggregator annotation.
AggregatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
AggregatorFactoryBean - Class in org.springframework.integration.config
AggregatorFactoryBean() - Constructor for class org.springframework.integration.config.AggregatorFactoryBean
 
AggregatorParser - Class in org.springframework.integration.config.xml
Parser for the aggregator element of the integration namespace.
AggregatorParser() - Constructor for class org.springframework.integration.config.xml.AggregatorParser
 
AggregatorSpec - Class in org.springframework.integration.dsl
AggregatorSpec() - Constructor for class org.springframework.integration.dsl.AggregatorSpec
 
allEndpointsRunning(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return true if all endpoints in the role are running.
allocate(int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Allocates a ByteBuffer of the requested length using normal or direct buffers, depending on the usingDirectBuffers field.
allowCredentials(Boolean) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
Whether the browser should include any cookies associated with the domain of the request being annotated.
allowedHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
List of request headers that can be used during the actual request.
AllowListDeserializingConverter - Class in org.springframework.integration.support.converter
A Converter that delegates to a Deserializer to convert data in a byte array to an object.
AllowListDeserializingConverter() - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
Create a AllowListDeserializingConverter with default ObjectInputStream configuration, using the "latest user-defined ClassLoader".
AllowListDeserializingConverter(ClassLoader) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
Create a AllowListDeserializingConverter for using an ObjectInputStream with the given ClassLoader.
AllowListDeserializingConverter(Deserializer<Object>) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
Create a AllowListDeserializingConverter that delegates to the provided Deserializer.
alwaysAccept(F) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
 
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 a AmqpInboundChannelAdapter.
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 for AmqpInboundGateway 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
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 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 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,T>,T extends AbstractAmqpChannel> - 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,T>,T extends AbstractAmqpChannel> - 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
 
AnnotatedMethodFilter - Class in org.springframework.integration.util
A MethodFilter implementation that enables the following: matching on method name, if available exclusion of void-returning methods if 'requiresReply' is true limiting to annotated methods if at least one is present
AnnotatedMethodFilter(Class<? extends Annotation>, String, boolean) - Constructor for class org.springframework.integration.util.AnnotatedMethodFilter
 
AnnotationConfigParser - Class in org.springframework.integration.config.xml
Parser for the <annotation-config> element of the integration namespace.
AnnotationConfigParser() - Constructor for class org.springframework.integration.config.xml.AnnotationConfigParser
 
AnnotationConstants - Class in org.springframework.integration.annotation
Common value constants for annotation attributes.
AnnotationGatewayProxyFactoryBean - Class in org.springframework.integration.gateway
A GatewayProxyFactoryBean extension for Java configuration.
AnnotationGatewayProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
 
AnnotationMetadataAdapter - Class in org.springframework.integration.config.annotation
An AnnotationMetadata implementation to expose a metadata by the provided Map of attributes.
AnnotationMetadataAdapter() - Constructor for class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
annotationType - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
ApacheCommonsFileTailingMessageProducer - Class in org.springframework.integration.file.tail
File tailer that delegates to the Apache Commons Tailer.
ApacheCommonsFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
ApacheMinaFtpEvent - Class in org.springframework.integration.ftp.server
ApplicationEvent generated from Apache Mina ftp events.
ApacheMinaFtpEvent(Object) - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
 
ApacheMinaFtpEvent(Object, Throwable) - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
 
ApacheMinaFtplet - Class in org.springframework.integration.ftp.server
A listener for FTP events emitted by an Apache Mina ftp server.
ApacheMinaFtplet() - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
ApacheMinaSftpEvent - Class in org.springframework.integration.sftp.server
ApplicationEvent generated from Apache Mina sftp events.
ApacheMinaSftpEvent(Object) - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
 
ApacheMinaSftpEvent(Object, Throwable) - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
 
ApacheMinaSftpEventListener - Class in org.springframework.integration.sftp.server
A listener for SFTP events emitted by an Apache Mina sshd/sftp server.
ApacheMinaSftpEventListener() - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
APP_NAME - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
append(Message<?>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Send a file to a remote server, based on information in a message, appending.
append(Message<?>, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Send a file to a remote server, based on information in a message, appending.
append(Message<?>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
append(Message<?>, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
append(InputStream, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
append(InputStream, String) - Method in interface org.springframework.integration.file.remote.session.Session
Append to a file.
append(InputStream, String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
append(InputStream, String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
appendNewLine(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
If true will append a new-line after each write.
appendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
An inbound Channel Adapter that implements GenericApplicationListener and passes Spring ApplicationEvents within messages.
ApplicationEventListeningMessageProducer() - Constructor for class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
ApplicationEventMulticasterParser - Class in org.springframework.integration.config.xml
Parser for the <application-event-multicaster> element of the integration namespace.
ApplicationEventMulticasterParser() - Constructor for class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
ApplicationEventPublishingMessageHandler - Class in org.springframework.integration.event.outbound
A MessageHandler that publishes each Message it receives as a MessagingEvent.
ApplicationEventPublishingMessageHandler() - Constructor for class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
 
apply(MessageGroup) - Method in class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
 
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
 
apply(Statement, Description) - Method in class org.springframework.integration.test.support.LongRunningIntegrationTest
 
APPLY_SEQUENCE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
applyAndBind(String, Iterable<T>, EntityManager) - Static method in class org.springframework.integration.jpa.support.JpaUtils
Creates a where-clause referencing the given entities and appends it to the given query string.
applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Add the advice chain to the component that responds to AbstractPollingEndpoint.receiveMessage() calls.
applySequence(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
applySequence(boolean) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
applySequence(boolean) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Set the applySequence flag to the specified value.
applySequence(boolean) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
A boolean flag to indicate if sequenceDetails should be applied for messages based on the lines from file.
applySystemFileSeparator(String) - Static method in class org.springframework.integration.test.util.TestUtils
Update file path by replacing any '/' with the system's file separator.
ARGUMENT_RESOLVER_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ArgumentsStrategy - Interface in org.springframework.integration.redis.outbound
 
asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
 
asFileInfoList(Collection<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
asFileInfoList(Collection<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
 
asMap() - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
assemble(E) - Method in class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
 
assemble(E) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
assemble(MarshallingWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
assemble(SimpleWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
 
assemble(SimpleWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
 
assertHandler() - Method in class org.springframework.integration.dsl.EndpointSpec
 
assertions - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
assertReceived(String) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
assertReceiver() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
assertRemoteFileTemplateMutability(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
async(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
 
async(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Allow async replies.
async(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Set to true to release the sending thread and receive the reply asynchronously.
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
 
asyncConvertAndSend(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertAndSend(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertAndSend(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertAndSend(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertAndSend(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertAndSend(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncConvertSendAndReceive(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncExecutor(Executor) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Provide a reference to an implementation of Executor to use for any of the interface methods that have a Future return type.
AsyncMessagingOperations - Interface in org.springframework.integration.core
 
AsyncMessagingTemplate - Class in org.springframework.integration.core
 
AsyncMessagingTemplate() - Constructor for class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncOutboundGateway(AsyncRabbitTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
Create an initial AmqpAsyncOutboundGatewaySpec.
asyncReceive() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceive(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceive(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceive() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncReceive(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncReceive(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncReceiveAndConvert() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceiveAndConvert(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncReceiveAndConvert() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncReceiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncReceiveAndConvert(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSend(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSend(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSend(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSend(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSend(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSend(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
 
asyncSendAndReceive(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSendAndReceive(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
asyncSendMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
ATTACHMENT_FILENAME - Static variable in class org.springframework.integration.mail.MailHeaders
 
attachmentFilename(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a filename for the attachment.
attachmentFilenameExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set an expression that will be evaluated to determine the filename for the attachment.
attachmentFilenameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the filename for the attachment.
AttributePollingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
AttributePollingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
 
AttributePollingMessageSource - Class in org.springframework.integration.jmx
A MessageSource implementation that retrieves the current value of a JMX attribute each time AbstractMessageSource.receive() is invoked.
AttributePollingMessageSource() - Constructor for class org.springframework.integration.jmx.AttributePollingMessageSource
 
AUTO_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
AUTO_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
AUTO_CREATE_CHANNEL_CANDIDATES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
AUTO_STARTUP - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
autoAck(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
ACCEPT an AcknowledgmentCallback if it's not null, supports auto ack and is not already ack'd.
autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
When configured to false, the folder is not closed automatically after a fetch.
autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
When configured to false, the folder is not closed automatically after a fetch.
autoCreateDirectChannel(String, BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Specify whether to create the source directory automatically if it does not yet exist upon initialization.
autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
A boolean flag to indicate automatically create the directory or not.
autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Specify whether to create the destination directory automatically if it does not yet exist upon initialization.
autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Determine whether the remote directory should automatically be created when sending files to the remote system.
autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure whether the local directory should be created by the adapter.
autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
A boolean flag to identify if local directory should be created automatically.
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().
autoNack(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
REJECT an AcknowledgmentCallback if it's not null, supports auto ack and is not already ack'd.
autoStartup(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
autoStartup(boolean) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
The boolean flag to indication if an IntegrationFlow must be started automatically after registration.
autoStartup(boolean) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
The boolean flag to indication if an IntegrationFlow must be started automatically after registration.
autoStartup(boolean) - Method in class org.springframework.integration.dsl.EndpointSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.MessageProducerSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
An auto-startup flag.
autoStartup(boolean) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
availablePermits() - Method in class org.springframework.integration.util.UpperBound
 
AvroHeaders - Class in org.springframework.integration.transformer.support
Pre-defined names and prefixes for Apache Avro related headers.
await() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 

B

BACKLOG - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
backlog(int) - Method in class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
 
backOff(BackOff) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
Specify a BackOff.
barrier(long) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a BarrierMessageHandler instance for provided timeout.
barrier(long, Consumer<BarrierSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a BarrierMessageHandler instance for provided timeout and options from BarrierSpec and endpoint options from GenericEndpointSpec.
BarrierMessageHandler - Class in org.springframework.integration.aggregator
A message handler that suspends the thread until a message with corresponding correlation is passed into the trigger method or the timeout occurs.
BarrierMessageHandler(long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and default correlation and output strategies.
BarrierMessageHandler(long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierMessageHandler(long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and correlation strategy, and default output processor.
BarrierMessageHandler(long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierMessageHandler(long, long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeouts and default correlation and output strategies.
BarrierMessageHandler(long, long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierMessageHandler(long, long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and correlation strategy, and default output processor.
BarrierMessageHandler(long, long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierParser - Class in org.springframework.integration.config.xml
Parser for <int:barrier/>.
BarrierParser() - Constructor for class org.springframework.integration.config.xml.BarrierParser
 
BarrierSpec - Class in org.springframework.integration.dsl
BarrierSpec(long) - Constructor for class org.springframework.integration.dsl.BarrierSpec
 
BASE_PACKAGE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
BaseHttpInboundEndpoint - Class in org.springframework.integration.http.inbound
The MessagingGatewaySupport extension for HTTP Inbound endpoints with basic properties.
BaseHttpInboundEndpoint(boolean) - Constructor for class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
BaseHttpInboundEndpointSpec<S extends BaseHttpInboundEndpointSpec<S,E>,E extends HttpRequestHandlingEndpointSupport> - Class in org.springframework.integration.http.dsl
BaseHttpInboundEndpointSpec(E, String...) - Constructor for class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
 
BaseHttpMessageHandlerSpec<S extends BaseHttpMessageHandlerSpec<S,E>,E extends AbstractHttpRequestExecutingMessageHandler> - Class in org.springframework.integration.http.dsl
BaseHttpMessageHandlerSpec(E) - Constructor for class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
BaseIntegrationFlowDefinition<B extends BaseIntegrationFlowDefinition<B>> - Class in org.springframework.integration.dsl
The Builder pattern implementation for the EIP-method chain.
BaseIntegrationFlowDefinition() - Constructor for class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
BaseIntegrationFlowDefinition.ReplyProducerCleaner - Class in org.springframework.integration.dsl
 
BaseWsInboundGatewaySpec<S extends BaseWsInboundGatewaySpec<S,E>,E extends AbstractWebServiceInboundGateway> - Class in org.springframework.integration.ws.dsl
Base MessagingGatewaySpec for web services.
BaseWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
Construct an instance.
BaseWsOutboundGatewaySpec<S extends BaseWsOutboundGatewaySpec<S,E>,E extends AbstractWebServiceOutboundGateway> - Class in org.springframework.integration.ws.dsl
BaseWsOutboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
BasicMessageGroupStore - Interface in org.springframework.integration.store
Defines a minimal message group store with basic capabilities.
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
 
batchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Set the message converter to use with a batch-based consumer.
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.
bcc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the bcc: addresses.
BCC - Static variable in class org.springframework.integration.mail.MailHeaders
 
bccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine the bcc: addresses.
bccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the bcc: addresses based on the message.
BEAN_NAME - Static variable in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
 
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
BeanDefinitionRegisteringParser - Interface in org.springframework.integration.config.xml
Simple strategy interface for parsers that are responsible for parsing an element, creating a bean definition, and then registering the bean.
beanFactory - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
BeanFactoryChannelResolver - Class in org.springframework.integration.support.channel
DestinationResolver implementation based on a Spring BeanFactory.
BeanFactoryChannelResolver() - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
Create a new instance of the BeanFactoryChannelResolver class.
BeanFactoryChannelResolver(BeanFactory) - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
Create a new instance of the BeanFactoryChannelResolver class.
BeanFactoryTypeConverter - Class in org.springframework.integration.util
 
BeanFactoryTypeConverter() - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
 
BeanFactoryTypeConverter(ConversionService) - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
 
beanName(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Specify a bean name for the target GatewayProxyFactoryBean.
BeanNameMessageProcessor<T> - Class in org.springframework.integration.handler
An "artificial" MessageProcessor for lazy-load of target bean by its name.
BeanNameMessageProcessor(String, String) - Constructor for class org.springframework.integration.handler.BeanNameMessageProcessor
 
BeanPropertyParameterSource - Class in org.springframework.integration.jpa.support.parametersource
 
BeanPropertyParameterSource(Object) - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
Create a new BeanPropertySqlParameterSource for the given bean.
BeanPropertyParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
 
BeanPropertyParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
 
BeanPropertySqlParameterSourceFactory - Class in org.springframework.integration.jdbc
A default implementation of SqlParameterSourceFactory which creates an SqlParameterSource to reference bean properties in its input.
BeanPropertySqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
 
beforeCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
 
beforeHandle(Message<?>, MessageChannel, MessageHandler) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
beforeReceive(Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
 
beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.aop.MessageSourceMutator
Subclasses can decide whether to proceed with this poll.
beforeReceive(Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
Subclasses can decide whether to Joinpoint.proceed() or not.
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
 
beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
Invoked before the message source receive() method.
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
beforeShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
 
beforeShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
Called before shutdown begins.
beforeShutdown() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
beforeShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
beforeShutdown() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
beforeShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
beforeShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
BinaryToMessageConverter - Class in org.springframework.integration.mongodb.support
 
BinaryToMessageConverter() - Constructor for class org.springframework.integration.mongodb.support.BinaryToMessageConverter
 
bindFunction(BiFunction<DatabaseClient.GenericExecuteSpec, ?, DatabaseClient.GenericExecuteSpec>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
Set a BiFunction which is used to bind parameters into the update query.
bindPort(int) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Configure a port for TCP protocol binding via ZMQ.Socket.bind(String).
bindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
Set to true to bind the source message in the headers.
BODY - Static variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
bodyExtractor(BodyExtractor<?, ClientHttpResponse>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
Specify a BodyExtractor as an alternative to the expectedResponseType to allow to get low-level access to the received ClientHttpResponse.
BOOLEAN - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 
BooleanTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
Boolean XPath testing MessageSelector.
BooleanTestXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Create a boolean testing XPath MessageSelector supporting multiple namespaces.
BooleanTestXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Create a boolean testing XPath MessageSelector supporting a single namespace.
BooleanTestXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Create a boolean testing XPath MessageSelector with no namespace support.
BooleanTestXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Create a boolean testing XPath MessageSelector using the provided XPathExpression.
bounded() - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
 
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).
bridge() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a BridgeHandler to the current integration flow position.
bridge(Consumer<GenericEndpointSpec<BridgeHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a BridgeHandler to the current integration flow position.
BridgeFrom - Annotation Type in org.springframework.integration.annotation
Messaging Annotation to mark a Bean method for a MessageChannel to produce a BridgeHandler and Consumer Endpoint.
BridgeFromAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @BridgeFrom annotation.
BridgeFromAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
BridgeHandler - Class in org.springframework.integration.handler
A simple MessageHandler implementation that passes the request Message directly to the output channel without modifying it.
BridgeHandler() - Constructor for class org.springframework.integration.handler.BridgeHandler
 
BridgeParser - Class in org.springframework.integration.config.xml
Parser for the <bridge> element.
BridgeParser() - Constructor for class org.springframework.integration.config.xml.BridgeParser
 
BridgeTo - Annotation Type in org.springframework.integration.annotation
Messaging Annotation to mark a Bean method for a MessageChannel to produce a BridgeHandler and Consumer Endpoint.
BridgeToAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @BridgeTo annotation.
BridgeToAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
BroadcastCapableChannel - Interface in org.springframework.integration.channel
A SubscribableChannel variant for implementations with broadcasting capabilities.
BroadcastingDispatcher - Class in org.springframework.integration.dispatcher
A broadcasting dispatcher implementation.
BroadcastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(Executor, boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastPublishSubscribeSpec - Class in org.springframework.integration.dsl
An IntegrationComponentSpec for configuring sub-flow subscribers on the provided BroadcastCapableChannel.
BroadcastPublishSubscribeSpec(BroadcastCapableChannel) - Constructor for class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
 
bufferSize(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the buffer size to use while writing to files; default 8192.
build() - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapFinalBuilder
 
build() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
Build the counter.
build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
Build the gauge.
build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
Build the timer.
build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
 
build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
 
build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
 
build() - Method in class org.springframework.integration.support.MessageBuilder
 
build() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
build() - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
Subclasses must implement this method to create the bean definition.
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PointToPointChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishSubscribeChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisChannelParser
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
 
buildErrorMessage(Message<?>, Exception) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Build an error message for the exception and message using the configured ErrorMessageStrategy.
buildErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Build an error message for the message and throwable using the configured ErrorMessageStrategy.
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.DefaultErrorMessageStrategy
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in interface org.springframework.integration.support.ErrorMessageStrategy
Build the error message.
buildFlow() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
buildKey(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
The default key is the AbstractPersistentAcceptOnceFileListFilter.prefix plus the full filename.
buildLambdaMessageProcessorForBeanMethod(Method, Object) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
buildMessage(Object) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
 
buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
buildReply(MessageConverter, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
buildResolvableType(ClassLoader, Object, Object, Object) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
Build a ResolvableType for provided class components.
buildResolvableType(Class<?>, Class<?>, Class<?>) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
Build a ResolvableType for provided class components.
buildResult(Object, Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Override to change the default mechanism by which the inbound and release messages are returned as a result.
buildReturnedMessage(Message, int, String, String, String, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
buildReturnedMessage(ReturnedMessage, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
buildSendTimer(boolean, String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
buildSendTimer(boolean, String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
ByteArrayCrLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
Reads data in an InputStream to a byte[]; data must be terminated by \r\n (not included in resulting byte[]).
ByteArrayCrLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
 
ByteArrayElasticRawDeserializer - Class in org.springframework.integration.ip.tcp.serializer
A deserializer that uses a ByteArrayOutputStream instead of a fixed buffer, allowing the buffer to grow as needed.
ByteArrayElasticRawDeserializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
Construct an instance that uses ByteArrayOutputStreams with an initial buffer size of 32;
ByteArrayElasticRawDeserializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
Construct an instance that uses ByteArrayOutputStreams with the provided initial buffer size.
ByteArrayLengthHeaderSerializer - Class in org.springframework.integration.ip.tcp.serializer
Reads data in an InputStream to a byte[]; data must be preceded by a binary length (network byte order, not included in resulting byte[]).
ByteArrayLengthHeaderSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
ByteArrayLengthHeaderSerializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Construct the serializer using the supplied header size.
ByteArrayLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
 
ByteArrayLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLfSerializer
 
ByteArrayRawSerializer - Class in org.springframework.integration.ip.tcp.serializer
A byte array (de)serializer that does nothing with the payload; sends it raw.
ByteArrayRawSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
 
ByteArrayRawSerializer(boolean) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
Treat socket timeouts as a normal EOF and emit the (possibly partial) message.
ByteArraySingleTerminatorSerializer - Class in org.springframework.integration.ip.tcp.serializer
Reads data in an InputStream to a byte[]; data must be terminated by a single byte (not included in resulting byte[]).
ByteArraySingleTerminatorSerializer(byte) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
 
ByteArrayStxEtxSerializer - Class in org.springframework.integration.ip.tcp.serializer
Reads data in an InputStream to a byte[]; data must be prefixed by <stx> and terminated by <etx> (not included in resulting byte[]).
ByteArrayStxEtxSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
BytesMessageMapper - Interface in org.springframework.integration.mapping
An OutboundMessageMapper and InboundMessageMapper that maps to/from byte[].
bytesToString(byte[], String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Utility method for null-safe conversion from byte[] to String
ByteStreamReadingMessageSource - Class in org.springframework.integration.stream
A pollable source for receiving bytes from an InputStream.
ByteStreamReadingMessageSource(InputStream) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
ByteStreamReadingMessageSource(InputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
ByteStreamWritingMessageHandler - Class in org.springframework.integration.stream
A MessageHandler that writes a byte array to an OutputStream.
ByteStreamWritingMessageHandler(OutputStream) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
 
ByteStreamWritingMessageHandler(OutputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
 

C

cacheLevel(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
Specify the level of caching that this listener container is allowed to apply.
cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
cacheLevelName(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
Specify the level of caching that this listener container is allowed to apply, in the form of the name of the corresponding constant: e.g.
CacheListeningMessageProducer - Class in org.springframework.integration.gemfire.inbound
An inbound endpoint that listens to a GemFire region for events and then publishes Messages to a channel.
CacheListeningMessageProducer(Region<?, ?>) - Constructor for class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
 
CacheRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
The AbstractRequestHandlerAdvice implementation for caching AbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message) results.
CacheRequestHandlerAdvice(String...) - Constructor for class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Create a CacheRequestHandlerAdvice instance based on the provided name of caches and CacheableOperation as default one.
CacheWritingMessageHandler - Class in org.springframework.integration.gemfire.outbound
A MessageHandler implementation that writes to a GemFire Region.
CacheWritingMessageHandler(Region) - Constructor for class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
CachingClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Connection factory that caches connections from the underlying target factory.
CachingClientConnectionFactory(AbstractClientConnectionFactory, int) - Constructor for class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
Construct a caching connection factory that delegates to the provided factory, with the provided pool size.
CachingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
A SessionFactory implementation that caches Sessions for reuse without requiring reconnection each time the Session is retrieved from the factory.
CachingSessionFactory(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
Create a CachingSessionFactory with an unlimited number of sessions.
CachingSessionFactory(SessionFactory<F>, int) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
Create a CachingSessionFactory with the specified session limit.
CachingSessionFactory.CachedSession - Class in org.springframework.integration.file.remote.session
 
call() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
 
CallerBlocksPolicy - Class in org.springframework.integration.util
A RejectedExecutionHandler that blocks the caller until the executor has room in its queue, or a timeout occurs (in which case a RejectedExecutionException is thrown.
CallerBlocksPolicy(long) - Constructor for class org.springframework.integration.util.CallerBlocksPolicy
Construct instance based on the provided maximum wait time.
canAdd(Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
This method determines whether messages have been added to this group that supersede the given message based on its sequence id.
canAdd(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
Query if the message can be added.
canAdd(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.FilterFactoryBean
MessageFilter is an ARPMH.
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.RouterFactoryBean
 
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
Always returns true - any AbstractMessageProducingHandler can be used directly.
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
Always returns true - any AbstractMessageProducingHandler can be used directly.
cancelIdleInterval(long) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
How often to recycle the idle task (in case of a silently dropped connection).
cancelPing() - Method in class org.springframework.integration.mail.ImapMailReceiver
The hook to be called when we need to cancel the current ping task and close the mail folder.
canConvert(Class<?>, Class<?>) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
canConvert(TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
Candidate - Interface in org.springframework.integration.leader
Interface that defines the contract for candidates to participate in a leader election.
canRead(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
canRead(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
Evaluate the expression provided on the MessageGroup and return the result (must be boolean).
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MessageCountReleaseStrategy
Release the group if it has more messages than the threshold and has not previously been released.
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
canRelease(MessageGroup) - Method in interface org.springframework.integration.aggregator.ReleaseStrategy
 
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
 
canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
canWrite(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
capacity(int) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
 
capacity - Variable in class org.springframework.integration.dsl.QueueChannelSpec
 
capacity(Integer) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
 
categories(String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
Specify the categories for logging level adjusting configured before.
categories(boolean, String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
Specify the categories for logging level adjusting configured before.
cause - Variable in class org.springframework.integration.events.IntegrationEvent
 
cc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the cc: addresses.
CC - Static variable in class org.springframework.integration.mail.MailHeaders
 
ccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine the cc: addresses.
ccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the cc: addresses based on the message.
ChainFileListFilter<F> - Class in org.springframework.integration.file.filters
The CompositeFileListFilter extension which chains the result of the previous filter to the next one.
ChainFileListFilter() - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
 
ChainFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
 
ChainParser - Class in org.springframework.integration.config.xml
Parser for the <chain> element.
ChainParser() - Constructor for class org.springframework.integration.config.xml.ChainParser
 
CHANGE_STREAM_OPERATION_TYPE - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
The header for change stream event type.
CHANGE_STREAM_RESUME_TOKEN - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
The header for change stream event resume token.
CHANGE_STREAM_TIMESTAMP - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
The header for change stream event timestamp.
changeStreamInboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a MongoDbChangeStreamMessageProducerSpec builder instance based on the provided ReactiveMongoOperations.
channel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
Create an initial AmqpMessageChannelSpec.
channel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
Create an initial AmqpMessageChannelSpec.
channel(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageChannelReference instance at the current IntegrationFlow chain position.
channel(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageChannel instance at the current IntegrationFlow chain position using the MessageChannelSpec fluent API.
channel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided MessageChannel instance at the current IntegrationFlow chain position.
channel(Function<Channels, MessageChannelSpec<?, ?>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageChannel instance at the current IntegrationFlow chain position using the Channels factory fluent API.
channel - Variable in class org.springframework.integration.dsl.MessageChannelSpec
 
channel(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageChannelSpec.
channel(String, ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageChannelSpec.
channel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create a spec for a subscribable channel with the provided parameters.
CHANNEL_INITIALIZER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
CHANNEL_RESOLVER_BEAN_NAME - Static variable in class org.springframework.integration.support.channel.ChannelResolverUtils
 
ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
Interface to encapsulate ConfigAttributes for secured channel send and receive operations.
ChannelInterceptorList(LogAccessor) - Constructor for class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
ChannelInterceptorParser - Class in org.springframework.integration.config.xml
A helper class for parsing the sub-elements of a channel's interceptors element.
ChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.ChannelInterceptorParser
 
ChannelInvocation - Class in org.springframework.integration.security.channel
Secured object for ChannelSecurityInterceptor.
ChannelInvocation(MethodInvocation) - Constructor for class org.springframework.integration.security.channel.ChannelInvocation
 
channelMapping(K, String) - Method in class org.springframework.integration.dsl.RouterSpec
 
channelMapping(K, MessageChannel) - Method in class org.springframework.integration.dsl.RouterSpec
The router mapping configuration based on the provided generic key and MessageChannel bean.
ChannelMessageStore - Interface in org.springframework.integration.store
A marker interface that indicates this message store has optimizations for use in a QueueChannel.
ChannelMessageStorePreparedStatementSetter - Class in org.springframework.integration.jdbc.store.channel
Callback to be used with the JdbcChannelMessageStore.
ChannelMessageStorePreparedStatementSetter(SerializingConverter, LobHandler) - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
Instantiate a ChannelMessageStorePreparedStatementSetter with the provided serializer and lobHandler, which both must not be null.
ChannelMessageStorePreparedStatementSetter() - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
The default constructor for inheritors who are not interested in the message serialization to byte[].
ChannelMessageStoreQueryProvider - Interface in org.springframework.integration.jdbc.store.channel
Common interface used in order to configure the JdbcChannelMessageStore to provide database-specific queries.
channelNameToChannel(String) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
channelNameToChannel(String) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
Converts the channel name back to a MessageChannel (if it is registered).
ChannelPublishingJmsMessageListener - Class in org.springframework.integration.jms
JMS MessageListener that converts a JMS Message into a Spring Integration Message and sends that Message to a channel.
ChannelPublishingJmsMessageListener() - Constructor for class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
ChannelPurger - Class in org.springframework.integration.channel
A utility class for purging Messages from one or more QueueChannels.
ChannelPurger(QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
 
ChannelPurger(MessageSelector, QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
 
channelResolver - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
channelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
Specify the DestinationResolver strategy to use.
ChannelResolverUtils - Class in org.springframework.integration.support.channel
Channel resolution utilities.
channels - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
Channels - Class in org.springframework.integration.dsl
 
CHANNELS_AUTOCREATE - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies whether to allow create automatically DirectChannel beans for non-declared channels or not.
CHANNELS_MAX_BROADCAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value for AbstractDispatcher.maxSubscribers in case of point-to-point channels (e.g.
CHANNELS_MAX_UNICAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value for AbstractDispatcher.maxSubscribers in case of point-to-point channels (e.g.
ChannelSecurityInterceptor - Class in org.springframework.integration.security.channel
An AOP interceptor that enforces authorization for MessageChannel send and/or receive calls.
ChannelSecurityInterceptor() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
ChannelSecurityInterceptor(ChannelSecurityMetadataSource) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
ChannelSecurityInterceptorBeanPostProcessor - Class in org.springframework.integration.security.config
ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>, Map<String, Map<Pattern, ChannelAccessPolicy>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
ChannelSecurityMetadataSource - Class in org.springframework.integration.security.channel
The SecurityMetadataSource implementation for secured MessageChannels.
ChannelSecurityMetadataSource() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
ChannelSecurityMetadataSource(Map<Pattern, ChannelAccessPolicy>) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
channelToChannelName(Object) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
channelToChannelName(Object, long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
channelToChannelName(Object) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
Converts the channel to a name (String).
channelToChannelName(Object, long) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
Converts the channel to a name (String).
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 the RabbitTemplate (for sends) and SimpleMessageListenerContainer (for receives) when using Spring Integration 4.0.
ChannelUtils - Class in org.springframework.integration.channel
Channel utilities.
CharacterStreamReadingMessageSource - Class in org.springframework.integration.stream
A pollable source for Readers.
CharacterStreamReadingMessageSource(Reader) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Construct an instance with the provider reader.
CharacterStreamReadingMessageSource(Reader, int) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Construct an instance with the provider reader and buffer size.
CharacterStreamReadingMessageSource(Reader, int, boolean) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Construct an instance with the provided reader and buffer size.
CharacterStreamWritingMessageHandler - Class in org.springframework.integration.stream
A MessageHandler that writes characters to a Writer.
CharacterStreamWritingMessageHandler(Writer) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
CharacterStreamWritingMessageHandler(Writer, int) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
charset(String) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
Set the charset to be used when reading the file, when something other than the default charset is required.
charset(Charset) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
Set the charset to be used when reading the file, when something other than the default charset is required.
charset(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the charset to use when converting String payloads to bytes as the content of the remote file.
charset(Charset) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the charset to use when converting String payloads to bytes as the content of the remote file.
charset(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the charset to use when converting String payloads to bytes as the content of the file.
charset(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the charset to use when converting String payloads to bytes as the content of the remote file.
charset(String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify the charset name to use for converting String-typed payloads to bytes.
CHAT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
ChatMessageInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for the XMPP 'inbound-channel-adapter' element.
ChatMessageInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
 
ChatMessageListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
This component logs in as a user and forwards any messages to that user on to downstream components.
ChatMessageListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
ChatMessageListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
ChatMessageOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for the XMPP 'outbound-channel-adapter' element
ChatMessageOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
 
ChatMessageSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
MessageHandler that sends an XMPP Chat Message.
ChatMessageSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
ChatMessageSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
checkActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
checkActive() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
checkAllowList(Class<?>) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
 
checkAndConfigureFixedSubscriberChannel(Element, ParserContext, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
checkClosure(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
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.
checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
 
checkMessageHandlerAttributes(String, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
checkReuse(MessageProducer) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
Creates a default task executor if none was supplied.
chmod(int) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the file permissions after uploading, e.g.
chmod(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the file permissions after uploading, e.g.
chmod(int) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file permissions after uploading, e.g.
CircuitBreakerOpenException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException
 
claimCheckIn(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
claimCheckIn(MessageStore, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
ClaimCheckInParser - Class in org.springframework.integration.config.xml
Parser for the <claim-check-in/> element.
ClaimCheckInParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckInParser
 
ClaimCheckInTransformer - Class in org.springframework.integration.transformer
Transformer that stores a Message and returns a new Message whose payload is the id of the stored Message.
ClaimCheckInTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckInTransformer
Create a claim check-in transformer that will delegate to the provided MessageStore.
claimCheckOut(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
claimCheckOut(MessageStore, boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckOutTransformer with provided MessageStore and removeMessage flag.
claimCheckOut(MessageStore, boolean, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckOutTransformer with provided MessageStore and removeMessage flag.
ClaimCheckOutParser - Class in org.springframework.integration.config.xml
Parser for the <claim-check-out/> element.
ClaimCheckOutParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckOutParser
 
ClaimCheckOutTransformer - Class in org.springframework.integration.transformer
Transformer that accepts a Message whose payload is a UUID and retrieves the Message associated with that id from a MessageStore if available.
ClaimCheckOutTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckOutTransformer
Create a claim check-out transformer that will delegate to the provided MessageStore.
classes(Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
Specify the classes for logging level adjusting configured before.
classes(boolean, Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
Specify the classes for logging level adjusting configured before.
ClassUtils - Class in org.springframework.integration.util
 
ClassUtils() - Constructor for class org.springframework.integration.util.ClassUtils
 
clear() - Method in class org.springframework.integration.channel.QueueChannel
 
clear() - Method in interface org.springframework.integration.channel.QueueChannelOperations
Remove all Messages from this channel.
clear() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
clear() - Method in class org.springframework.integration.history.MessageHistory
 
clear() - Method in interface org.springframework.integration.store.MessageGroup
 
clear() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
clear() - Method in class org.springframework.integration.support.MutableMessageHeaders
 
clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Clear the resource bundle cache.
clearMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
clearOnFlush(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
If set to true the EntityManager.clear() will be called, and only if the EntityManager.flush() was called after performing persistence operations.
clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
Clear the Redis Queue specified by RedisQueueInboundGateway.boundListOperations.
clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
Clear the Redis Queue specified by RedisQueueMessageDrivenEndpoint.boundListOperations.
clearThreadKey() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Clear the key for this thread.
clearThreadKey(Message<?>) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Messaging-friendly version of DelegatingSessionFactory.clearThreadKey() that can be invoked from a service activator.
CLIENT_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
CLIENT_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
CLIENT_MODE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
ClientCallback<C,T> - Interface in org.springframework.integration.file.remote
RemoteFileTemplate callback with the underlying client instance providing access to lower level methods.
ClientCallbackWithoutResult<C> - Interface in org.springframework.integration.file.remote
RemoteFileTemplate callback with the underlying client instance providing access to lower level methods where no result is returned.
ClientHttpResponseBodyExtractor - Class in org.springframework.integration.webflux.support
The BodyExtractor identity function implementation which just returns the provided ClientHttpResponse.
ClientHttpResponseBodyExtractor() - Constructor for class org.springframework.integration.webflux.support.ClientHttpResponseBodyExtractor
 
clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
 
clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
ClientModeCapable - Interface in org.springframework.integration.ip.tcp.connection
Edpoints implementing this interface are capable of running in client-mode.
ClientModeConnectionManager - Class in org.springframework.integration.ip.tcp.connection
Intended to be run on a schedule, simply gets the connection from a client connection factory each time it is run.
ClientModeConnectionManager(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
 
ClientRSocketConnector - Class in org.springframework.integration.rsocket
A client AbstractRSocketConnector extension to the RSocket connection.
ClientRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
Instantiate a connector based on the TcpClientTransport.
ClientRSocketConnector(URI) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
Instantiate a connector based on the WebsocketClientTransport.
ClientRSocketConnector(ClientTransport) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
Instantiate a connector based on the provided ClientTransport.
clientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a ClientRSocketConnector for client side requests based on the connection provided by the ClientRSocketConnector.getRequester().
ClientStompEncoder - Class in org.springframework.integration.websocket.support
A StompEncoder extension to prepare a message for sending/receiving before/after encoding/decoding when used from WebSockets client side.
ClientStompEncoder() - Constructor for class org.springframework.integration.websocket.support.ClientStompEncoder
 
ClientWebSocketContainer - Class in org.springframework.integration.websocket
The IntegrationWebSocketContainer implementation for the client Web-Socket connection.
ClientWebSocketContainer(WebSocketClient, String, Object...) - Constructor for class org.springframework.integration.websocket.ClientWebSocketContainer
 
ClientWebSocketContainerParser - Class in org.springframework.integration.websocket.config
The AbstractSingleBeanDefinitionParser implementation for the <websocket:client-container/> element.
ClientWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
 
cloneAndExecute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
Call this when it is necessary to clone the invocation before calling proceed() - such as when the invocation might be called multiple times - for example in a retry advice.
cloneConnectOptions(MqttConnectOptions) - Static method in class org.springframework.integration.mqtt.support.MqttUtils
Clone the MqttConnectOptions, except the serverUris.
close() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
close() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
close() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
close() - Method in interface org.springframework.integration.file.remote.session.Session
 
close() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
close() - Method in class org.springframework.integration.ftp.session.FtpSession
 
close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
close() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Closes the connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Closes this connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Closes this connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
close() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
close() - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
close() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
close() - Method in class org.springframework.integration.sftp.session.SftpSession
 
close() - Method in interface org.springframework.integration.util.CloseableIterator
 
close() - Method in class org.springframework.integration.util.FunctionIterator
 
close() - Method in interface org.springframework.integration.util.Pool
Close the pool; returned items will be destroyed.
close() - Method in class org.springframework.integration.util.SimplePool
 
CLOSEABLE_RESOURCE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
CloseableIterator<E> - Interface in org.springframework.integration.util
A CloseableIterator is intended to be used when it may hold resources (such as file or socket handles).
closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Close a connection with the specified connection id.
closeConnection(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
If we have been intercepted, propagate the close from the outermost interceptor; otherwise, just call close().
closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
closeFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
closeFolder(Folder, boolean) - Static method in class org.springframework.integration.mail.MailTransportUtils
Close the given JavaMail Folder and ignore any thrown exception.
closeService(Service) - Static method in class org.springframework.integration.mail.MailTransportUtils
Close the given JavaMail Service and ignore any thrown exception.
closeSession(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
closeStreamAfterSend(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Set to true to close the connection output stream after sending without closing the connection.
Codec - Interface in org.springframework.integration.codec
Interface for classes that perform both encode (serialize) and decode (deserialize) on multiple classes.
codecConfigurer(ServerCodecConfigurer) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
 
CodecMessageConverter - Class in org.springframework.integration.codec
A MessageConverter that delegates to a Codec to convert
CodecMessageConverter(Codec) - Constructor for class org.springframework.integration.codec.CodecMessageConverter
 
collection(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Configure a collection to subscribe for change events.
COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
The header for MongoDb collection name.
CollectionArgumentResolver - Class in org.springframework.integration.handler.support
CollectionArgumentResolver(boolean) - Constructor for class org.springframework.integration.handler.support.CollectionArgumentResolver
 
collectionCallback(MessageCollectionCallback<P>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
Reference to an instance of MessageCollectionCallback which specifies the database operation to execute in the request message context.
CollectionFilter<T> - Interface in org.springframework.integration.util
Base strategy for filtering out a subset of a Collection of elements.
collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
Identify the name of the MongoDb collection to use.
collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
Configure a collection name to store data.
collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Configure a collection name to query against.
collectionName - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
A SpEL expression which should resolve to a String value identifying the name of the MongoDb collection to use.
collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
Configure a SpEL expression to evaluate a collection name against a request message.
collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Configure a SpEL expression to evaluation a collection name on each receive() call.
collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Configure a SpEL expression to evaluation a collection name on each receive() call.
collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
A Function which should resolve to a String (e.q., collectionNameFunction(Message::getPayload)).
collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
Configure a Function for evaluation a collection against request message.
collectionNameSupplier(Supplier<String>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Configure a Supplier to obtain a collection name on each receive() call.
COMMAND - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
commonOutboundProperties(Element, ParserContext, BeanDefinitionBuilder) - Static method in class org.springframework.integration.kafka.config.xml.KafkaParsingUtils
 
CommonSocketOptions - Interface in org.springframework.integration.ip
 
comparator(Comparator<Message<?>>) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
 
compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.MessageSequenceComparator
 
compareTo(FileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
compareTo(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
compareValues(BiPredicate<String, String>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
COMPLETE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
complete() - Method in interface org.springframework.integration.store.MessageGroup
Complete the group.
complete() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
completeGroup(Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
completeGroup(Message<?>, Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
completeGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
completeGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
completeGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Completes this MessageGroup.
completeGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
ComponentsEvaluationCallback(EvaluationContext, Object, boolean, Class<?>) - Constructor for class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
 
ComponentsRegistration - Interface in org.springframework.integration.dsl
The marker interface for the IntegrationComponentSpec implementation, when there is need to register as beans not only the target spec's components, but some additional components, e.g.
componentsToRegister - Variable in class org.springframework.integration.dsl.EndpointSpec
 
componentsToRegister - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
CompositeCodec - Class in org.springframework.integration.codec
A Codec that can delegate to one out of many Codecs, each mapped to a class.
CompositeCodec(Map<Class<?>, Codec>, Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
 
CompositeCodec(Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
 
CompositeExecutor - Class in org.springframework.integration.util
An Executor that encapsulates two underlying executors.
CompositeExecutor(Executor, Executor) - Constructor for class org.springframework.integration.util.CompositeExecutor
 
CompositeFileListFilter<F> - Class in org.springframework.integration.file.filters
Simple FileListFilter that predicates its matches against all of the configured FileListFilter.
CompositeFileListFilter() - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
 
CompositeFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
 
CompositeKryoRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar that delegates and validates registrations across all components.
CompositeKryoRegistrar(List<KryoRegistrar>) - Constructor for class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
CompositeMessageHandler - Interface in org.springframework.integration.handler
Classes implementing this interface delegate to a list of handlers.
CompositeMessageHandlerNode - Class in org.springframework.integration.graph
Represents a composite message handler.
CompositeMessageHandlerNode(int, String, MessageHandler, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.graph.CompositeMessageHandlerNode
 
CompositeMessageHandlerNode.InnerHandler - Class in org.springframework.integration.graph
 
CompoundTrigger - Class in org.springframework.integration.util
A Trigger that delegates the CompoundTrigger.nextExecutionTime(TriggerContext) to one of two Triggers.
CompoundTrigger(Trigger) - Constructor for class org.springframework.integration.util.CompoundTrigger
Construct a compound trigger with the supplied primary trigger.
CompoundTriggerAdvice - Class in org.springframework.integration.aop
A MessageSourceMutator that uses a CompoundTrigger to adjust the poller - when a message is present, the compound trigger's primary trigger is used to determine the next poll.
CompoundTriggerAdvice(CompoundTrigger, Trigger) - Constructor for class org.springframework.integration.aop.CompoundTriggerAdvice
 
concurrency(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The concurrency to use.
concurrency(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Specify a concurrency maximum number for the AbstractMessageListenerContainer.
concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The concurrent consumers number to use.
concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
concurrentConsumers(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
Supports atomic updates to values in the store.
ConfigurableCompositeMessageConverter - Class in org.springframework.integration.support.converter
A CompositeMessageConverter extension with some default MessageConverters which can be overridden with the given converters or added in the end of target converters collection.
ConfigurableCompositeMessageConverter() - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
Create an instance with the default converters.
ConfigurableCompositeMessageConverter(Collection<MessageConverter>) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
Create an instance with the given converters and without defaults.
ConfigurableCompositeMessageConverter(Collection<MessageConverter>, boolean) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
Create an instance with the given converters and with defaults in the end.
ConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
An alternate MongoDB MessageStore and MessageGroupStore which allows the user to configure the instance of MongoTemplate.
ConfigurableMongoDbMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
configure(IntegrationFlowDefinition<?>) - Method in interface org.springframework.integration.dsl.IntegrationFlow
The callback-based function to declare the chain of EIP-methods to configure an integration flow with the provided IntegrationFlowDefinition.
configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
configure(DatagramSocket) - Method in interface org.springframework.integration.ip.udp.SocketCustomizer
Configure the socket ({code setTrafficClass()}, etc).
configure(RmiProxyFactoryBean) - Method in interface org.springframework.integration.rmi.RmiOutboundGateway.RmiProxyFactoryBeanConfigurer
Deprecated.
Perform additional configuration of the factory bean before the RequestReplyExchanger is created.
configureAdviceChain(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
configureAdviceChain(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
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<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
 
configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
 
configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
 
configureFilter(BeanDefinitionBuilder, Element, ParserContext, String, String, String) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
configureHandler(ServiceActivatingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, Class<?>, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, BeanDefinitionBuilder, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
Configure the channel adapter to use the template specification created by invoking the Consumer callback, passing in a JmsTemplateSpec.
configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
 
configureKafkaTemplate(Consumer<KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K, V, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
Configure a Kafka Template by invoking the Consumer callback, with a KafkaTemplateSpec argument.
configureKafkaTemplate(Consumer<KafkaTemplateSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
Configure a Kafka Template by invoking the Consumer callback, with a KafkaTemplateSpec argument.
configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
Subclasses implement this to configure the kryo instance.
configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.PojoCodec
 
configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a JmsListenerContainerSpec argument.
configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageListenerContainerSpec argument.
configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageListenerContainerSpec argument.
configureMappingRouter(AbstractMappingMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
 
configurePollerMetadata(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Parse a "poller" element to provide a reference for the target BeanDefinitionBuilder.
configurePollingEndpoint(AbstractPollingEndpoint, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
configureRouter(AbstractMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
 
configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
Configure the socket.
configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
Configure the socket.
configureSource(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
configureSplitter(AbstractMessageSplitter) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
configureTemplate(Consumer<KafkaTemplateSpec<K, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
Configure a template by invoking the Consumer callback, with a KafkaTemplateSpec argument.
configureTransactionAttributes(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Parse a "transactional" element and configure a TransactionInterceptor with "transactionManager" and other "transactionDefinition" properties.
configureTransactionAttributes(Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Parse a "transactional" element and configure a TransactionInterceptor or TransactionHandleMessageAdvice with "transactionManager" and other "transactionDefinition" properties.
configureTransactionDefinition(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Parse attributes of "transactional" element and configure a DefaultTransactionAttribute with provided "transactionDefinition" properties.
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.
connect() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Perform subscription into the RSocket server for incoming requests.
connect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
connect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
 
CONNECT_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
A unique identifier for a TCP connection; set by the framework for inbound messages; when sending to a server-side inbound channel adapter, or replying to an inbound gateway, this header is required so the endpoint can determine which connection to send the message to.
connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
 
ConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
A factory used to create TcpConnection objects.
connectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
 
connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
connectTimeout(int) - Method in class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
Set the connection timeout in seconds.
connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
Configure a connection to the ZeroMQ proxy with the pair of ports over colon for proxy frontend and backend sockets.
connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Configure an URL for ZMQ.Socket.connect(String).
consecutiveActiveTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
consecutiveIdleTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
ConsoleInboundChannelAdapterParser - Class in org.springframework.integration.stream.config
Parser for the <stdin-channel-adapter> element.
ConsoleInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleInboundChannelAdapterParser
 
ConsoleOutboundChannelAdapterParser - Class in org.springframework.integration.stream.config
Parser for the "stdout-" and "stderr-channel-adapter" elements.
ConsoleOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleOutboundChannelAdapterParser
 
CONSOLIDATED_HEADERS - Static variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
Header containing List<Map<String, Object> headers when batch mode is AmqpInboundChannelAdapter.BatchMode.EXTRACT_PAYLOADS_WITH_HEADERS.
constructType(Type) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
constructType(Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
Specify a Duration to delay consumption when no data received.
consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Specify a Duration to delay consumption when no data received.
CONSUMER - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
CONSUMER_GROUP - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
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.
ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
The FactoryBean implementation for AbstractEndpoint population.
ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
ConsumerEndpointSpec<S extends ConsumerEndpointSpec<S,H>,H extends MessageHandler> - Class in org.springframework.integration.dsl
A EndpointSpec for consumer endpoints.
ConsumerEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.ConsumerEndpointSpec
 
consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the user defined ConsumerRebalanceListener implementation.
consumersPerQueue(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
 
ConsumerStopAction - Enum in org.springframework.integration.mqtt.core
Action to take regarding subscrptions when consumer stops.
consumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Set the implementation of ConsumerTagStrategy to generate consumer tags.
consumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the executor for threads that poll the consumer.
consumes(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
The consumable media types of the mapped request, narrowing the primary mapping.
container(ConnectionFactory, Destination) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsListenerContainerSpec.
container(ConnectionFactory, String) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsListenerContainerSpec.
containerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
Configure the type of the container.
contains(Object) - Method in class org.springframework.integration.history.MessageHistory
 
containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
containsElementIgnoreCase(String[], String) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
containsKey(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
containsSequence(Integer) - Method in class org.springframework.integration.store.SimpleMessageGroup
Return true if a message with this sequence number header exists in the group.
containsValue(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
CONTENT_MD5 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_TYPE - Static variable in class org.springframework.integration.mail.MailHeaders
 
CONTENT_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
CONTENT_TYPE_PROPERTY - Static variable in class org.springframework.integration.jms.JmsHeaderMapper
 
ContentBasedHeaderMatcher(boolean, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
 
ContentEnricher - Class in org.springframework.integration.transformer
Content Enricher is a Message Transformer that can augment a message's payload with either static values or by optionally invoking a downstream message flow via its request channel and then applying values from the reply Message to the original payload.
ContentEnricher() - Constructor for class org.springframework.integration.transformer.ContentEnricher
 
contentType(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the content type.
contentTypeExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set an expression that will be evaluated to determine the content type.
contentTypeFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the content type.
Context - Interface in org.springframework.integration.leader
Interface that defines the context for candidate leadership.
ContinuousQueryMessageProducer - Class in org.springframework.integration.gemfire.inbound
Responds to a Gemfire continuous query (set using the #query field) that is constantly evaluated against a cache Region.
ContinuousQueryMessageProducer(ContinuousQueryListenerContainer, String) - Constructor for class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
controlBus() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Control Bus EI Pattern specific MessageHandler implementation at the current IntegrationFlow chain position.
controlBus(Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Control Bus EI Pattern specific MessageHandler implementation at the current IntegrationFlow chain position.
ControlBusMethodFilter - Class in org.springframework.integration.expression
SpEL MethodFilter to restrict method invocations to: Pausable or Lifecycle components get, set and shutdown methods of CustomizableThreadCreator methods with ManagedAttribute and ManagedOperation annotations This class isn't designed for target applications and typically is used from ExpressionControlBusFactoryBean.
ControlBusMethodFilter() - Constructor for class org.springframework.integration.expression.ControlBusMethodFilter
 
ControlBusParser - Class in org.springframework.integration.config.xml
 
ControlBusParser() - Constructor for class org.springframework.integration.config.xml.ControlBusParser
 
conversionService - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
convert(Class<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided payloadType to convert at runtime.
convert(Class<P>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided payloadType to convert at runtime.
convert(MBeanServerConnection, ObjectInstance) - Method in class org.springframework.integration.jmx.DefaultMBeanObjectConverter
 
convert(MBeanServerConnection, ObjectInstance) - Method in interface org.springframework.integration.jmx.MBeanObjectConverter
 
convert(Binary) - Method in class org.springframework.integration.mongodb.support.BinaryToMessageConverter
 
convert(Message<?>) - Method in class org.springframework.integration.mongodb.support.MessageToBinaryConverter
 
convert(byte[]) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
 
convert(JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
convert(Object) - Method in class org.springframework.integration.util.UUIDConverter
Convert the input to a UUID using the convenience method UUIDConverter.getUUID(Object).
convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
convertAndSend(Message<?>) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
converter - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
converter(Converter<T, U>) - Static method in class org.springframework.integration.dsl.Transformers
 
CONVERTER_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ConverterParser - Class in org.springframework.integration.config.xml
 
ConverterParser() - Constructor for class org.springframework.integration.config.xml.ConverterParser
 
convertExceptions(boolean) - Method in class org.springframework.integration.http.dsl.HttpRequestHandlerEndpointSpec
Flag to determine if conversion and writing out of message handling exceptions should be attempted.
convertExpressions(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
Utility method that converts a Collection of ProcedureParameter to a Map containing only expression parameters.
convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.integration.support.converter.ObjectStringMessageConverter
 
ConvertingBytesMessageMapper - Class in org.springframework.integration.mapping
The BytesMessageMapper implementation to delegate to/from Message conversion into the provided MessageConverter.
ConvertingBytesMessageMapper(MessageConverter) - Constructor for class org.springframework.integration.mapping.ConvertingBytesMessageMapper
 
convertPayload(Message) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
convertRequestMappingToAnnotation(RequestMapping) - Static method in class org.springframework.integration.http.config.HttpContextUtils
Converts a provided RequestMapping to the Spring Web RequestMapping annotation.
convertStaticParameters(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
Utility method that converts a Collection of ProcedureParameter to a Map containing only static parameters.
convertToDocument(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
convertToDocument(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
 
convertToJdbcTypesEnum(String) - Static method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
Retrieves the matching enum constant for a provided String representation of the SQL Types.
convertToNode(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
convertToNode(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
 
convertToSource(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
convertToSource(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
 
convertToString(Object) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
convertValue(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
copy(MessageGroup) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Used by expireMessageGroups.
copy(MessageGroup) - Method in class org.springframework.integration.store.SimpleMessageStore
 
copyFileToLocalDirectory(String, F, File, Session<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Copy the name-value pairs from the provided Map.
copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
Copy the name-value pairs from the provided Map.
copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Copy the name-value pairs from the provided Map.
copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
Copy the name-value pairs from the provided Map.
copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
copyToSizedArray(byte[], int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
Copy size bytes to a new buffer exactly size bytes long.
CorrelatingMessageBarrier - Class in org.springframework.integration.aggregator
This Endpoint serves as a barrier for messages that should not be processed yet.
CorrelatingMessageBarrier() - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
CorrelatingMessageBarrier(MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
CORRELATION_ID - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
correlationExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an ExpressionEvaluatingCorrelationStrategy for the given expression.
CorrelationHandlerSpec<S extends CorrelationHandlerSpec<S,H>,H extends AbstractCorrelatingMessageHandler> - Class in org.springframework.integration.dsl
CorrelationHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.CorrelationHandlerSpec
 
correlationId(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
correlationId(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
correlationIdExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.CORRELATION_ID header where the value is a SpEL Expression evaluation result.
correlationIdExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.CORRELATION_ID header where the value is a SpEL Expression evaluation result.
correlationIdFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.CORRELATION_ID header where the value is obtained by invoking the Function callback.
correlationIdFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.CORRELATION_ID header where the value is obtained by invoking the Function callback.
correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
CorrelationStrategy - Interface in org.springframework.integration.aggregator
Strategy for determining how messages can be correlated.
CorrelationStrategy - Annotation Type in org.springframework.integration.annotation
Indicates that a given method is capable of determining the correlation key of a message sent as parameter.
correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.BarrierSpec
 
correlationStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an MethodInvokingCorrelationStrategy for the target object and method name.
correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
CorrelationStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a CorrelationStrategy.
CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
counterBuilder(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Create a counter builder for a counter with the provided name.
counterBuilder(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
CounterFacade - Interface in org.springframework.integration.support.management.metrics
 
CqEventType - Enum in org.springframework.integration.gemfire.inbound
Enumeration of GemFire Continuous Query Event Types
create(Message<?>, String, Integer, Long, K, V, Headers) - Method in interface org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler.ProducerRecordCreator
Create a record.
create(Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
Create a MessageGroup instance based on the provided groupId.
create(Collection<? extends Message<?>>, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
Create a MessageGroup instance based on the provided groupId and with the messages for the group.
create(Collection<? extends Message<?>>, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
Create a MessageGroup instance based on the provided groupId and with the messages for the group.
create(MessageGroupStore, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
Create a MessageGroup instance based on the provided groupId.
create(MessageGroupStore, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
Create a MessageGroup instance based on the provided groupId.
create(Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
 
create(Collection<? extends Message<?>>, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
 
create(Collection<? extends Message<?>>, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
 
create(MessageGroupStore, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
 
create(MessageGroupStore, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
 
create(Object) - Method in class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
 
create(Object) - Method in class org.springframework.integration.transaction.PassThroughTransactionSynchronizationFactory
 
create(Object) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationFactory
 
create() - Method in class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
create() - Method in class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
 
create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
 
createCallback(T) - Method in interface org.springframework.integration.acks.AcknowledgmentCallbackFactory
Create the callback.
createCallback(AmqpMessageSource.AmqpAckInfo) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
 
createCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 
createClientInstance() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
 
createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
createConnection() - Method in class org.springframework.integration.jms.JmsOutboundGateway
Create a new JMS Connection for this JMS gateway.
createConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
created(ServerSession, Path, Map<String, ?>, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
createDefaultHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createDefaultHandler() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
createDefaultHeaderMatcher(String, Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Create the initial AbstractHeaderMapper.HeaderMatcher based on the specified headers and standard header prefix.
createDirectChannel(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
createDirectHandlerIfPossible(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
If the target object is a MessageHandler and the method is 'handleMessage', return an AbstractMessageProducingHandler that wraps it.
createDispatcher() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
 
createDispatcher() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
createDispatcher() - Method in class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
 
createDispatcher() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
createElementDescription(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Provides a user friendly description of an element based on its node name and, if available, its "id" attribute value.
createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
createEvaluationContext() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
createEvaluationContext() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
createEvaluationContext() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.FilterFactoryBean
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.RouterFactoryBean
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
createFilter(MessageSelector) - Method in class org.springframework.integration.config.FilterFactoryBean
 
createForPool() - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when a new instance is required to populate the pool.
createHandler() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
createHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createHandler() - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
Subclasses must implement this method to create the MessageHandler.
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
 
createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
 
createHandler() - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
createHandler(Transformer) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
createHandler() - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
createHandler() - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
createHandler() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
createHeaderMatcher(Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Create a AbstractHeaderMapper.HeaderMatcher that match if any of the specified patterns match.
createInstance() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
createInstance() - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
createInstance() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
createInstance() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
createInstance() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
createInstance() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
createInstance() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
createInstance() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
createInstance() - Method in class org.springframework.integration.sftp.session.JschProxyFactoryBean
 
createInstance() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
createInstance() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
createJsonParser(String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
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
 
createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.groovy.config.GroovyAwareScriptExecutingProcessorFactory
 
createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
 
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Subclasses must implement this method to create the MessageHandler.
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
 
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
 
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
createMethodInvokingRouter(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
 
createMethodInvokingSplitter(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetConnectionSupport
 
createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
 
createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNetConnectionSupport
Create a new TcpNetConnection object wrapping the Socket.
createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNioConnectionSupport
Create a new TcpNioConnection object wrapping the SocketChannel
createOutputMessage(Object, MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
createOutputStream(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Create a buffered output stream for the file.
createParameterSource(Object) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
 
createParameterSource(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
 
createParameterSource(Object) - Method in interface org.springframework.integration.jdbc.SqlParameterSourceFactory
Return a new SqlParameterSource.
createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
 
createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
createParameterSource(Object) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSourceFactory
Return a new ParameterSource.
createParameterSourceNoCache(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Create an expression evaluating SqlParameterSource that does not cache it's results.
createResult(Object) - Method in class org.springframework.integration.xml.result.DomResultFactory
 
createResult(Object) - Method in interface org.springframework.integration.xml.result.ResultFactory
 
createResult(Object) - Method in class org.springframework.integration.xml.result.StringResultFactory
 
createSelect(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
 
createSelect(SqlIdentifier) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
 
createServerSocket(int, int, InetAddress) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
Create a new ServerSocket.
createSession(Connection) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Create a new JMS Session using the provided Connection.
createSimpleEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
Used to create a context with no BeanFactory, usually in tests.
createSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory is null.
createSocket(String, int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
Create a new Socket.
createSource(Object) - Method in class org.springframework.integration.xml.source.DomSourceFactory
 
createSource(Object) - Method in interface org.springframework.integration.xml.source.SourceFactory
Create appropriate Source instance for payload
createSource(Object) - Method in class org.springframework.integration.xml.source.StringSourceFactory
 
createStandardEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
Used to create a context with no BeanFactory, usually in tests.
createStandardEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory is null.
createTargetPropertyName(String, boolean) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Alter the specified propertyName if necessary.
createTaskScheduler(int) - Static method in class org.springframework.integration.test.util.TestUtils
A factory for the ThreadPoolTaskScheduler instances based on the provided poolSize.
createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
Create a TestUtils.TestApplicationContext instance supplied with the basic Spring Integration infrastructure.
createWriter(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Create a buffered writer for the file, for String payloads.
credentials(String, String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the credentials.
criteria(Function<Message<P>, Criteria>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a Function to evaluate a Criteria for query to execute.
criteria(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a Criteria for query to execute.
criteria(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a Criteria for query to execute.
crlf() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
crlf(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
cron(String) - Method in class org.springframework.integration.dsl.PollerFactory
 
cron(String, TimeZone) - Method in class org.springframework.integration.dsl.PollerFactory
 
cron(String) - Static method in class org.springframework.integration.dsl.Pollers
 
cron(String, TimeZone) - Static method in class org.springframework.integration.dsl.Pollers
 
crossOrigin(Consumer<HttpInboundEndpointSupportSpec.CrossOriginSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
CrossOrigin - Class in org.springframework.integration.http.inbound
The mapping to permit cross origin requests (CORS) for HttpRequestHandlingEndpointSupport.
CrossOrigin() - Constructor for class org.springframework.integration.http.inbound.CrossOrigin
 
CuratorFrameworkFactoryBean - Class in org.springframework.integration.zookeeper.config
A Spring-friendly way to build a CuratorFramework and implementing SmartLifecycle.
CuratorFrameworkFactoryBean(String) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
Construct an instance using the supplied connection string and using a default retry policy new ExponentialBackoffRetry(1000, 3).
CuratorFrameworkFactoryBean(String, RetryPolicy) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
Construct an instance using the supplied connection string and retry policy.
current() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
currentComponent(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
currentInterceptableChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Return the current channel if it is an InterceptableChannel, otherwise register a new implicit DirectChannel in the flow and return that one.
currentMessageChannel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
customizeMonoReply(BiFunction<Message<?>, Mono<?>, Publisher<?>>) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Specify a BiFunction for customizing Mono replies via ReactiveRequestHandlerAdvice.

D

DatagramPacketMessageMapper - Class in org.springframework.integration.ip.udp
Message Mapper for converting to and from UDP DatagramPackets.
DatagramPacketMessageMapper() - Constructor for class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
datatype(Class<?>...) - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
DATE_FORMATS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
deBatchingEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Determine whether or not the container should de-batch batched messages (true) or call the listener with the batch (false).
debug() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
The factory to produce Log4j2LevelAdjuster instances for Level.DEBUG logging with the org.springframework.integration as default category.
decode(InputStream, Class<T>) - Method in interface org.springframework.integration.codec.Codec
Decode an object of a given type
decode(byte[], Class<T>) - Method in interface org.springframework.integration.codec.Codec
Decode an object of a given type
decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
 
decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
 
decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
DECODE_ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
decodeFluxAsUnit(boolean) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
Configure an option to decode an incoming Flux as a single unit or each its event separately.
decoding(Codec, Class<T>) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, String) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, Function<Message<?>, Class<T>>) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, Expression) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the DecodingTransformer.
DecodingTransformer<T> - Class in org.springframework.integration.transformer
AbstractPayloadTransformer that delegates to a codec to decode the payload from a byte[].
DecodingTransformer(Codec, Class<T>) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
Construct an instance to use the supplied codec to decode to the supplied type.
DecodingTransformer(Codec, Expression) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
Construct an instance to use the supplied codec to decode to the supplied type.
decorate(MessageHandlingRunnable) - Method in interface org.springframework.integration.dispatcher.MessageHandlingTaskDecorator
 
decorateMessage(Message<?>) - Method in interface org.springframework.integration.support.MessageDecorator
 
Default - Annotation Type in org.springframework.integration.annotation
Indicates that the class member has some default meaning.
DEFAULT_ADVICE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_BUSY_WAIT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
DEFAULT_CHARSET - Static variable in class org.springframework.integration.util.UUIDConverter
 
DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
The default conventional collection name.
DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
The default completion timeout in milliseconds.
DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
The default completion timeout in milliseconds.
DEFAULT_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
DEFAULT_DELAY_WHEN_EMPTY - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
A default delay before repeating an empty source Mono as 1 second Duration.
DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
DEFAULT_ERROR_CODE - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The View model key for the error code.
DEFAULT_ERROR_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_ERRORS_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The View model key for errors.
DEFAULT_FILE_REGISTRATION_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_GENERIC_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_HALF_OPEN_AFTER - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
A half-open duration as 1000 .
DEFAULT_HASH_MAP_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_HEADER_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
DEFAULT_HEART_BEAT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
DEFAULT_MAX_ATTEMPTS - Static variable in class org.springframework.integration.handler.DelayHandler
 
DEFAULT_MAX_MESSAGE_SIZE - Static variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
The default maximum message size when deserializing.
DEFAULT_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_MUTABLE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_MUTABLE_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_NAME - Static variable in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
 
DEFAULT_POLLER - Static variable in class org.springframework.integration.scheduling.PollerMetadata
A convenient short alias for the global default poller bean name.
DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.scheduling.PollerMetadata
 
DEFAULT_POLLING_PERIOD - Static variable in class org.springframework.integration.endpoint.AbstractPollingEndpoint
A default polling period for PeriodicTrigger.
DEFAULT_PORT - Static variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.endpoint.PollingConsumer
A default receive timeout as 1000L milliseconds.
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.jms.JmsOutboundGateway
A default receive timeout in milliseconds.
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
DEFAULT_REGION - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Default region property, used to partition the message store.
DEFAULT_REPLY_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The View model key for reply.
DEFAULT_REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
DEFAULT_RETRY_DELAY - Static variable in class org.springframework.integration.handler.DelayHandler
 
DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpInboundGateway
A default retry interval in milliseconds - 60000L.
DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
A default retry interval for the ClientModeConnectionManager rescheduling.
DEFAULT_SEND_BUFFER_SIZE - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
DEFAULT_SEND_TIME_LIMIT - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
DEFAULT_SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
Default user flag for marking messages as seen by this receiver: "spring-integration-mail-adapter".
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Default value for the table prefix property.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
Default value for the table prefix property.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Default value for the table prefix property.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcMessageStore
Default value for the table prefix property.
DEFAULT_TAIL_ATTEMPTS_DELAY - Static variable in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
The default delay between tail attempts in milliseconds.
DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
Default threshold is effectively infinite.
DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
A default failures threshold as 5.
DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
Default timeout is one minute.
DEFAULT_TTL - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Default value for the time-to-live property.
DEFAULT_UUID_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DefaultAggregateHeadersFunction - Class in org.springframework.integration.aggregator
The Function implementation for a default headers merging in the aggregator component.
DefaultAggregateHeadersFunction() - Constructor for class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
 
DefaultAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
This implementation of MessageGroupProcessor will take the messages from the MessageGroup and pass them on in a single message with a Collection as a payload.
DefaultAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
 
DefaultAmqpHeaderMapper - Class in org.springframework.integration.amqp.support
Default implementation of AmqpHeaderMapper.
DefaultAmqpHeaderMapper(String[], String[]) - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
DefaultCandidate - Class in org.springframework.integration.leader
Simple Candidate for leadership.
DefaultCandidate() - Constructor for class org.springframework.integration.leader.DefaultCandidate
Instantiate a default candidate.
DefaultCandidate(String, String) - Constructor for class org.springframework.integration.leader.DefaultCandidate
Instantiate a default candidate.
DefaultChannelAccessPolicy - Class in org.springframework.integration.security.channel
Creates the ConfigAttributes for secured channel send and receive operations based on simple String values.
DefaultChannelAccessPolicy(String, String) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
Create an access policy instance.
DefaultChannelAccessPolicy(String[], String[]) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
Create an access policy instance.
DefaultDatatypeChannelMessageConverter - Class in org.springframework.integration.support.converter
Default message converter for datatype channels.
DefaultDatatypeChannelMessageConverter() - Constructor for class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
defaultDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
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.
DefaultDirectoryScanner - Class in org.springframework.integration.file
Default directory scanner and base class for other directory scanners.
DefaultDirectoryScanner() - Constructor for class org.springframework.integration.file.DefaultDirectoryScanner
defaultEncoding(String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the default encoding.
DefaultErrorMessageStrategy - Class in org.springframework.integration.support
A simple ErrorMessageStrategy implementations which produces a error message with original message if the AttributeAccessor has ErrorMessageUtils.INPUT_MESSAGE_CONTEXT_KEY attribute.
DefaultErrorMessageStrategy() - Constructor for class org.springframework.integration.support.DefaultErrorMessageStrategy
 
defaultFileNameFunction(String) - Static method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
The default function used to create the file name for the corresponding marker file.
DefaultFileNameGenerator - Class in org.springframework.integration.file
Default implementation of the filename generator strategy.
DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
 
defaultFileTypeMap(FileTypeMap) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the default type map.
DefaultFtpSessionFactory - Class in org.springframework.integration.ftp.session
Default implementation of FTP SessionFactory.
DefaultFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
 
DefaultFtpsSessionFactory - Class in org.springframework.integration.ftp.session
SessionFactory for FTPS.
DefaultFtpsSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
DefaultHeaderChannelRegistry - Class in org.springframework.integration.channel
Converts a channel to a name, retaining a reference to the channel keyed by the name.
DefaultHeaderChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Constructs a registry with the default delay for channel expiry.
DefaultHeaderChannelRegistry(long) - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Constructs a registry with the provided delay (milliseconds) for channel expiry.
DefaultHttpHeaderMapper - Class in org.springframework.integration.http.support
Default HeaderMapper implementation for HTTP.
DefaultHttpHeaderMapper() - Constructor for class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
DefaultInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the <inbound-channel-adapter/> element.
DefaultInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
 
DefaultJmsHeaderMapper - Class in org.springframework.integration.jms
Default implementation of JmsHeaderMapper.
DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.jms.DefaultJmsHeaderMapper
 
DefaultJpaOperations - Class in org.springframework.integration.jpa.core
Class similar to JPA template limited to the operations required for the JPA adapters/gateway not using JpaTemplate as the class is deprecated since Spring 3.1.
DefaultJpaOperations() - Constructor for class org.springframework.integration.jpa.core.DefaultJpaOperations
 
DefaultLeaderEventPublisher - Class in org.springframework.integration.leader.event
Default implementation of LeaderEventPublisher.
DefaultLeaderEventPublisher() - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
Instantiates a new leader event publisher.
DefaultLeaderEventPublisher(ApplicationEventPublisher) - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
Instantiates a new leader event publisher.
DefaultLockRegistry - Class in org.springframework.integration.support.locks
Default implementation of LockRegistry which uses Masked Hashcode algorithm to obtain locks.
DefaultLockRegistry() - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
Constructs a DefaultLockRegistry with the default mask 0xFF with 256 locks.
DefaultLockRegistry(int) - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
Constructs a DefaultLockRegistry with the supplied mask - the mask must have a value Math.pow(2, n) - 1 where n is 1 to 31, creating a hash of Math.pow(2, n) locks.
DefaultLockRepository - Class in org.springframework.integration.jdbc.lock
The default implementation of the LockRepository based on the table from the script presented in the org/springframework/integration/jdbc/schema-*.sql.
DefaultLockRepository(DataSource) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
Constructor that initializes the client id that will be associated for all the locks persisted by the store instance to a random UUID.
DefaultLockRepository(DataSource, String) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
Constructor that allows the user to specify a client id that will be associated for all the locks persisted by the store instance.
DefaultMailHeaderMapper - Class in org.springframework.integration.mail.support
Maps an inbound MimeMessage to a Map.
DefaultMailHeaderMapper() - Constructor for class org.springframework.integration.mail.support.DefaultMailHeaderMapper
 
DefaultMBeanAttributeFilter - Class in org.springframework.integration.jmx
 
DefaultMBeanAttributeFilter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
 
DefaultMBeanObjectConverter - Class in org.springframework.integration.jmx
 
DefaultMBeanObjectConverter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
 
DefaultMBeanObjectConverter(MBeanAttributeFilter) - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
 
DefaultMessageBuilderFactory - Class in org.springframework.integration.support
 
DefaultMessageBuilderFactory() - Constructor for class org.springframework.integration.support.DefaultMessageBuilderFactory
 
DefaultMessageConverter - Class in org.springframework.integration.syslog
Default MessageConverter; delegates to a SyslogToMapTransformer to convert the payload to a map of values and also provides some of the map contents as message headers.
DefaultMessageConverter() - Constructor for class org.springframework.integration.syslog.DefaultMessageConverter
 
DefaultMessageSplitter - Class in org.springframework.integration.splitter
The default Message Splitter implementation.
DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
 
DefaultMqttPahoClientFactory - Class in org.springframework.integration.mqtt.core
Creates a default MqttClient and a set of options as configured.
DefaultMqttPahoClientFactory() - Constructor for class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
DefaultMqttPahoClientFactory.Will - Class in org.springframework.integration.mqtt.core
 
DefaultMultipartFileReader - Class in org.springframework.integration.http.multipart
MultipartFileReader implementation that reads the MultipartFile content directly into a new MultipartFile instance that is not restricted to the HTTP request scope.
DefaultMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.DefaultMultipartFileReader
 
DefaultOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the <outbound-channel-adapter/> element.
DefaultOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
 
defaultOutputChannel(String) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify a MessageChannel bean name as a default output from the router.
defaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify a MessageChannel as a default output from the router.
defaultOutputToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Make a default output mapping of the router to the parent flow.
defaultOverwrite(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Determine the default action to take when setting individual header specifications without an explicit 'overwrite' argument.
DefaultPahoMessageConverter - Class in org.springframework.integration.mqtt.support
Default implementation for mapping to/from Messages.
DefaultPahoMessageConverter() - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter with default options (qos=0, retain=false, charset=UTF-8).
DefaultPahoMessageConverter(int, boolean) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter to create outbound messages with the supplied default qos and retain settings and a UTF-8 charset for converting outbound String payloads to byte[] and inbound byte[] to String (unless payloadAdBytes is true).
DefaultPahoMessageConverter(String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter with default options (qos=0, retain=false) and the supplied charset.
DefaultPahoMessageConverter(int, boolean, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter to create outbound messages with the supplied default qos and retain settings and the supplied charset.
DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter to create outbound messages with the supplied default qos and retained message processors and a UTF-8 charset for converting outbound String payloads to byte[] and inbound byte[] to String (unless payloadAdBytes is true).
DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Construct a converter to create outbound messages with the supplied default qos and retain settings and the supplied charset.
defaultQosProcessor() - Static method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
 
defaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
defaultReplyQueueName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
defaultReplyTimeout(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
Default reply timeout.
defaultReplyTo(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
The defaultReplyTo address with the form
 (exchange)/(routingKey)
defaultReplyTopicName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
defaultRequeueRejected(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
defaultRetainedProcessor() - Static method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
 
DefaultRouterParser - Class in org.springframework.integration.config.xml
Parser for the <router/> element.
DefaultRouterParser() - Constructor for class org.springframework.integration.config.xml.DefaultRouterParser
 
defaults() - Static method in class org.springframework.integration.context.IntegrationProperties
 
DefaultScriptExecutor - Class in org.springframework.integration.scripting.jsr223
Default implementation of the AbstractScriptExecutor.
DefaultScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.DefaultScriptExecutor
Create a DefaultScriptExecutor for the specified language name (JSR233 alias).
DefaultScriptVariableGenerator - Class in org.springframework.integration.scripting
A default ScriptVariableGenerator implementation; used by script processors.
DefaultScriptVariableGenerator() - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
 
DefaultScriptVariableGenerator(Map<String, Object>) - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
 
DefaultSessionFactoryLocator<F> - Class in org.springframework.integration.file.remote.session
The default implementation of SessionFactoryLocator using a simple map lookup and an optional default to fall back on.
DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
 
DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
 
DefaultSftpSessionFactory - Class in org.springframework.integration.sftp.session
Factory for creating SftpSession instances.
DefaultSftpSessionFactory() - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
DefaultSftpSessionFactory(boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
DefaultSftpSessionFactory(JSch, boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Intended for use in tests so the jsch can be mocked.
DefaultSoapHeaderMapper - Class in org.springframework.integration.ws
A HeaderMapper implementation for mapping to and from a SoapHeader.
DefaultSoapHeaderMapper() - Constructor for class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
defaultSubFlowMapping(IntegrationFlow) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify an IntegrationFlow as an output from the router when no any other mapping has matched.
DefaultTcpNetConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
Default implementation of TcpNetConnectionSupport.
DefaultTcpNetConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetConnectionSupport
 
DefaultTcpNetSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
Implementation of TcpSocketFactorySupport for non-SSL sockets ServerSocket and Socket.
DefaultTcpNetSocketFactorySupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
 
DefaultTcpNetSSLSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
Implementation of TcpSocketFactorySupport for SSL sockets SSLServerSocket and SSLSocket.
DefaultTcpNetSSLSocketFactorySupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
 
DefaultTcpNioConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
Implementation of TcpNioConnectionSupport for non-SSL NIO connections.
DefaultTcpNioConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
 
DefaultTcpNioSSLConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
Implementation of TcpNioConnectionSupport for SSL NIO connections.
DefaultTcpNioSSLConnectionSupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
Create an instance with host verification enabled.
DefaultTcpNioSSLConnectionSupport(TcpSSLContextSupport, boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
Create an instance.
DefaultTcpSocketSupport - Class in org.springframework.integration.ip.tcp.connection
Default implementation of TcpSocketSupport; makes no changes to sockets.
DefaultTcpSocketSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
Construct an instance with host verification enabled.
DefaultTcpSocketSupport(boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
Construct an instance with the provided sslVerifyHost.
DefaultTcpSSLContextSupport - Class in org.springframework.integration.ip.tcp.connection
Default implementation of TcpSSLContextSupport; uses a 'TLS' (by default) SSLContext, initialized with 'JKS' keystores, managed by 'SunX509' Key and Trust managers.
DefaultTcpSSLContextSupport(String, String, String, String) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
Prepares for the creation of an SSLContext using the supplied key/trust stores and passwords.
defaultTopic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
/** Set the default topic for send methods where a topic is not providing.
DefaultTransactionSynchronizationFactory - Class in org.springframework.integration.transaction
DefaultTransactionSynchronizationFactory(TransactionSynchronizationProcessor) - Constructor for class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
 
DefaultXmlPayloadConverter - Class in org.springframework.integration.xml
Default implementation of XmlPayloadConverter.
DefaultXmlPayloadConverter() - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
DefaultXmlPayloadConverter(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
DefaultXmppHeaderMapper - Class in org.springframework.integration.xmpp.support
Default implementation of XmppHeaderMapper.
DefaultXmppHeaderMapper() - Constructor for class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
defineRequestResponseScenario() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
 
defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
Implement this method to define RequestResponse scenarios
defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
 
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.
delay(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with default options.
delay(String, Consumer<DelayerEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position.
delay(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
The delay between checks of the file for new content in milliseconds.
DELAY_WHEN_EMPTY_KEY - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
The subscriber context entry for Flux.delayElements(java.time.Duration) from the Mono.repeatWhenEmpty(java.util.function.Function).
delayedAdvice(Advice...) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Configure a list of Advice objects that will be applied, in nested order, when delayed messages are sent.
delayedMessageErrorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Set a message channel to which an ErrorMessage will be sent if sending the released message fails.
delayedMessageErrorChannel(String) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Set a message channel name to which an ErrorMessage will be sent if sending the released message fails.
DelayerEndpointSpec - Class in org.springframework.integration.dsl
DelayerEndpointSpec(DelayHandler) - Constructor for class org.springframework.integration.dsl.DelayerEndpointSpec
 
DelayerParser - Class in org.springframework.integration.config.xml
Parser for the <delayer> element.
DelayerParser() - Constructor for class org.springframework.integration.config.xml.DelayerParser
 
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.
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.dsl.DelayerEndpointSpec
 
delayExpression(String) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
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.
delayFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Specify the function to determine delay value against Message.
DelayHandler - Class in org.springframework.integration.handler
A MessageHandler that is capable of delaying the continuation of a Message flow based on the result of evaluation delayExpression on an inbound Message or a default delay value configured on this handler.
DelayHandler(String) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given 'messageGroupId' that is used as 'key' for MessageGroup to store delayed Messages in the MessageGroupStore.
DelayHandler(String, TaskScheduler) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given default delay.
DelayHandler.DelayedMessageWrapper - Class in org.springframework.integration.handler
 
DelayHandlerManagement - Interface in org.springframework.integration.handler
 
delayRead(Selector, long, SelectionKey) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
DelegatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
The MessageGroupProcessor implementation with delegation to the provided delegate and optional aggregation for headers.
DelegatingMessageGroupProcessor(MessageGroupProcessor, Function<MessageGroup, Map<String, Object>>) - Constructor for class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
DelegatingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
SessionFactory that delegates to a SessionFactory retrieved from a SessionFactoryLocator.
DelegatingSessionFactory(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Construct an instance with a DefaultSessionFactoryLocator using the supplied factories and default key.
DelegatingSessionFactory(SessionFactoryLocator<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Construct an instance using the supplied factory.
delete(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
delete(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
delete(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
delete(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
DELETE_ALL_QUERY_STRING - Static variable in class org.springframework.integration.jpa.support.JpaUtils
 
deleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
If set to 'true', the retrieved objects are deleted from the database upon being polled.
deleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
If set to true, the retrieved objects are deleted from the database upon being polled.
deleteExpired() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
deleteExpired() - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
deleteInBatch(Iterable<?>) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
deleteInBatch(Iterable<?>) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
deleteInBatch(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
If not set, this property defaults to false, which means that deletion occurs on a per object basis if a collection of entities is being deleted.
deleteInBatch(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
If not set, this property defaults to false, which means that deletion occurs on a per object basis if a collection of entities is being deleted.
deleteMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Deletes the given messages from this receiver's folder.
deleteMessages(Message[]) - Method in class org.springframework.integration.mail.Pop3MailReceiver
Deletes the given messages from this receiver's folder, and closes it to expunge deleted messages.
deleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Set to true to enable deletion of remote files after successful transfer.
deleteSourceFiles(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Specify whether to delete source Files after writing to the destination directory.
delimiters(String) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Set delimiters to tokenize String values.
DELIVERY_ATTEMPT - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
deliveryModeExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Specify a SpEL expression to evaluate a deliveryMode for JMS message to send.
deliveryModeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Specify a Function to resolve a deliveryMode for JMS message to send.
deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
DerbyChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
DerbyChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
deriveLanguageFromFileExtension(String) - Static method in class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
Derive a scripting language from the provided script file name.
describeTo(Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.MessageMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
 
description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
Add the description.
description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
Add the description.
description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
Add the description.
description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
 
description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
 
description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
 
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
 
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
 
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Read the header from the stream and then reads the provided length from the stream and returns the data in a byte[].
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
 
deserialize(ByteArrayInputStream) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
 
deserialize(InputStream) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
deserializer(String...) - Static method in class org.springframework.integration.dsl.Transformers
 
deserializer(Deserializer<Object>, String...) - Static method in class org.springframework.integration.dsl.Transformers
 
deserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
Configure the destination from which to receive messages.
destination(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
Configure the name of destination from which to receive messages.
destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
destination(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
 
destination(String) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
Specify a destination name to use.
destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Configure the destination to which this adapter will send messages.
destination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Configure the name of the destination to which this adapter will send messages.
destination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Configure a Function that will be invoked at run time to determine the destination to which a message will be sent.
destination(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Configure the destination name that backs this channel.
destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Configure the destination that backs this channel.
DESTINATION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
destinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Configure a SpEL expression that will evaluate, at run time, the destination to which a message will be sent.
destinationProvider - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
destinationProvider(DestinationProvider) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Configure with a destination provider;
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
destroy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
destroy() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
destroy() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
destroy() - Method in class org.springframework.integration.channel.FluxMessageChannel
 
destroy() - Method in class org.springframework.integration.channel.NullChannel
 
destroy() - Method in class org.springframework.integration.channel.QueueChannel
 
destroy() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
destroy() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
destroy() - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
destroy() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
destroy() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Destroy the IntegrationFlow bean (as well as all its dependent beans) and clean up all the local cache for it.
destroy() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
destroy() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
destroy() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Remove (close) any unused sessions in the pool.
destroy() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
destroy() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
destroy() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
destroy() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
destroy() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
destroy() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
destroy() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
destroy() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
destroy() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
destroy() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
destroy() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
destroy() - Method in class org.springframework.integration.mail.ImapMailReceiver
 
destroy() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
destroy() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
destroy() - Method in class org.springframework.integration.redis.util.RedisLockRegistry
 
destroy() - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
destroy() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
 
destroy() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
destroy() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
destroy() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
destroy() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
destroy() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
destroy() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
destroy() - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
destroy() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
destroy() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
 
destroy() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
destroy() - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
 
destroying(ServerSession) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
destroyInstance(T) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
destroyInstance(AbstractJmsChannel) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
detectAlias(String) - Static method in class org.springframework.integration.jpa.support.JpaUtils
Resolves the alias for the entity to be retrieved from the given JPA query.
detectHandlerMethods(Object) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
detectHandlerMethods(Object) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
determinePayload(Throwable, AttributeAccessor) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Build a Throwable payload for future ErrorMessage.
determineRetryState(Message<?>) - Method in interface org.springframework.integration.handler.advice.RetryStateGenerator
 
determineRetryState(Message<?>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
 
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
Subclasses must implement this method to return a Collection of zero or more MessageChannels to which the given Message should be routed.
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter
 
direct() - Method in class org.springframework.integration.dsl.Channels
 
direct(String) - Method in class org.springframework.integration.dsl.Channels
 
direct() - Static method in class org.springframework.integration.dsl.MessageChannels
 
direct(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
DirectChannel - Class in org.springframework.integration.channel
A channel that invokes a single subscriber for each sent Message.
DirectChannel() - Constructor for class org.springframework.integration.channel.DirectChannel
Create a channel with default RoundRobinLoadBalancingStrategy
DirectChannel(LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.DirectChannel
Create a DirectChannel with a LoadBalancingStrategy.
DirectChannelSpec - Class in org.springframework.integration.dsl
 
DirectChannelSpec() - Constructor for class org.springframework.integration.dsl.DirectChannelSpec
 
DirectMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
DirectMessageListenerContainerSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
 
DirectoryCreatedEvent - Class in org.springframework.integration.ftp.server
An event emitted when a directory is created.
DirectoryCreatedEvent(FtpSession, FtpRequest) - Constructor for class org.springframework.integration.ftp.server.DirectoryCreatedEvent
 
DirectoryCreatedEvent - Class in org.springframework.integration.sftp.server
An event emitted when a directory is created.
DirectoryCreatedEvent(Object, Path, Map<String, ?>) - Constructor for class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
DirectoryScanner - Interface in org.springframework.integration.file
Strategy for scanning directories.
dirty() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
dirty() - Method in interface org.springframework.integration.file.remote.session.Session
Mark this session as dirty, indicating that it should not be reused and any delegated sessions should be taken care of before closing.
DiscardAwareFileListFilter<F> - Interface in org.springframework.integration.file.filters
The FileListFilter modification which can accept a Consumer which can be called when the filter discards the file.
discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
discardChannel(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Specify a channel where rejected Messages should be sent.
discardChannel(String) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Specify a channel name where rejected Messages should be sent.
discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Specify a channel where rejected Messages should be sent.
discardChannel(String) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Specify a channel bean name where rejected Messages should be sent.
discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Configure a subflow to run for discarded messages instead of a FilterEndpointSpec.discardChannel(MessageChannel).
discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Configure a subflow to run for discarded messages instead of a SplitterEndpointSpec.discardChannel(MessageChannel).
DiscardingMessageHandler - Interface in org.springframework.integration.handler
Classes implementing this interface are capable of discarding messages.
DiscardingMessageHandlerNode - Class in org.springframework.integration.graph
Represents an endpoint that has a discard channel.
DiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.graph.DiscardingMessageHandlerNode
 
discardWithinAdvice(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Set to 'true' if you wish the discard processing to occur within any request handler advice applied to this filter.
disconnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
disconnect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
 
DISCONNECT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
The default disconnect completion timeout in milliseconds.
DISCONNECT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
The default disconnect completion timeout in milliseconds.
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
dispatch(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
Dispatch the message.
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
 
dispatcher - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
disposables - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
DISPOSABLES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
doAddMessage(Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doBegin(Object, TransactionDefinition) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doChmod(RemoteFileOperations<F>, String, int) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the mode on the remote file after transfer; the default implementation does nothing.
doChmod(RemoteFileTemplate<F>, String, int) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Set the mode on the remote file after transfer; the default implementation does nothing.
doChmod(RemoteFileOperations<FTPFile>, String, int) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
doChmod(RemoteFileTemplate<FTPFile>, String, int) - Method in class org.springframework.integration.ftp.outbound.FtpMessageHandler
 
doChmod(RemoteFileOperations<ChannelSftp.LsEntry>, String, int) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
doChmod(RemoteFileTemplate<ChannelSftp.LsEntry>, String, int) - Method in class org.springframework.integration.sftp.outbound.SftpMessageHandler
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.ReactorNettyTcpStompSessionManager
 
doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.WebSocketStompSessionManager
 
doCreateEndpoint(MessageHandler, MessageChannel, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
DOCUMENT_LIST - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 
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
 
doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
Subclasses implement this method to decode with Kryo.
doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.PojoCodec
 
doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
 
doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
Reads the data in the inputStream to a byte[].
doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
 
doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
Reads the data in the inputStream to a byte[].
doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
Reads the data in the inputStream to a byte[].
doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
Subclasses implement this method to encode with Kryo.
doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.PojoCodec
 
doExecuteWithClient(ClientCallback<FTPClient, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
 
doExecuteWithClient(ClientCallback<ChannelSftp, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
 
doExtractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.BarrierSpec
 
doGet() - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
doGet() - Method in class org.springframework.integration.dsl.DirectChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.EndpointSpec
 
doGet() - Method in class org.springframework.integration.dsl.EnricherSpec
 
doGet() - Method in class org.springframework.integration.dsl.ExecutorChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
 
doGet() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
doGet() - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.PriorityChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.QueueChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
 
doGet() - Method in class org.springframework.integration.dsl.WireTapSpec
 
doGet() - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
 
doGet() - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
doGet() - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
doGet() - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
 
doGet() - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
 
doGet() - Method in class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
 
doGet() - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
doGetTransaction() - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
doHandleRequest(HttpServletRequest, RequestEntity<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Handles the HTTP request by generating a Message and sending it to the request channel.
doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.filter.MessageFilter
 
doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
doInCollection(MongoCollection<Document>, Message<?>) - Method in interface org.springframework.integration.mongodb.outbound.MessageCollectionCallback
Perform a Mongo operation in the collection using request message as a context.
doInCollection(MongoCollection<Document>) - Method in interface org.springframework.integration.mongodb.outbound.MessageCollectionCallback
 
doInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
doInit() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
doInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Subclasses can override to perform initialization - called from InitializingBean.afterPropertiesSet().
doInit() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
doInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Subclasses can override to perform initialization - called from InitializingBean.afterPropertiesSet().
doInit() - Method in class org.springframework.integration.filter.MessageFilter
 
doInit() - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
doInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
doInit() - Method in class org.springframework.integration.handler.DelayHandler
 
doInit() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
doInit() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
doInit() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
doInit() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
doInit() - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
 
doInit() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
doInit() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
doInit() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
doInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
doInit() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
doInit() - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
 
doInit() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
doInit() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
doInit() - Method in class org.springframework.integration.transformer.ContentEnricher
Initializes the Content Enricher.
doInit() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
doInit() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
doInit() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
doInOperations(RemoteFileOperations<F>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations.OperationsCallback
Execute any number of operations using a dedicated remote session as long as those operations are performed on the template argument and on the calling thread.
doInParser(JsonInboundMessageMapper, String, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonInboundMessageMapper.JsonMessageParser
 
doInSession(Session<F>, Message<?>) - Method in interface org.springframework.integration.file.remote.MessageSessionCallback
Called within the context of a session and requestMessage.
doInSession(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallback
Called within the context of a session.
doInSession(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallbackWithoutResult
 
doInSessionWithoutResult(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallbackWithoutResult
Called within the context of a session.
doInvoke(MethodInvocation, boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
Subclasses implement this method to apply behavior to the MessageHandler.
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
 
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
 
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
doInvoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
doInvoke(MessageContext) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
doInvoke(MessageContext) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
doListKeys(String) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doListKeys(String) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doListKeys(String) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
DOM_RESULT - Static variable in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
domainType(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Configure a domain type to convert change event body into.
DomResultFactory - Class in org.springframework.integration.xml.result
 
DomResultFactory() - Constructor for class org.springframework.integration.xml.result.DomResultFactory
 
DomResultFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.result.DomResultFactory
 
DomSourceFactory - Class in org.springframework.integration.xml.source
SourceFactory implementation which supports creation of a DOMSource from a Document, File or String payload.
DomSourceFactory() - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
 
DomSourceFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
 
doOffer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
It is assumed that the 'storeLock' is being held by the caller, otherwise IllegalMonitorStateException may be thrown
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
Subclasses must implement this method to parse the adapter element.
doParse(BeanDefinitionBuilder, Element, BeanMetadataElement, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorChainParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.event.config.EventInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireCqInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mqtt.config.xml.MqttMessageDrivenChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.webflux.config.WebFluxInboundEndpointParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.websocket.config.WebSocketInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
doParseAndRegisterConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this method to control the registration process and return the bean name.
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderValueRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RecipientListRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathRouterParser
 
doPoll(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
doPoll(ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
doPoll() - Method in class org.springframework.integration.store.MessageGroupQueue
It is assumed that the 'storeLock' is being held by the caller, otherwise IllegalMonitorStateException may be thrown
doPollForMessage(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
This method executes a call to the DB to get the oldest Message in the MessageGroup which in the context of the JdbcChannelMessageStore means the channel identifier.
doPollForMessage(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
This method executes a call to the DB to get the oldest Message in the MessageGroup Override this method if need to.
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
Subclasses may add to the bean definition by overriding this method.
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
Deprecated.
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
doReceive(Long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
doReceive() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
doReceive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
Subclasses must implement this method.
doReceive(long) - Method in class org.springframework.integration.channel.PriorityChannel
 
doReceive(long) - Method in class org.springframework.integration.channel.QueueChannel
 
doReceive() - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
 
doReceive(int) - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
Subclasses must implement this method.
doReceive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
Subclasses must implement this method.
doReceive() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
doReceive() - Method in class org.springframework.integration.endpoint.MessageProcessorMessageSource
 
doReceive() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
doReceive() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
doReceive() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
doReceive(int) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
doReceive(int) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Polls from the file source.
doReceive() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Execute the select query and the update query if provided.
doReceive() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
Execute the select query and the update query if provided.
doReceive() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Will receive a JMS Message converting and returning it as a Spring Integration Message.
doReceive() - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Retrieves the JMX attribute value.
doReceive() - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
Provides the mapped tree object
doReceive() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
Use JpaExecutor.poll() to executes the JPA operation.
doReceive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
doReceive() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
doReceive() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
doReceive() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Will execute a Query returning its results as the Message payload.
doReceive() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Execute a Query returning its results as the Message payload.
doReceive() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Execute a query returning its results as the Message payload.
doReceive() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
Returns a Message with the view into a RedisStore identified by RedisStoreMessageSource.keyExpression
doReceive() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
doReceive() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
 
doReceive() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
doReceive() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
doRemove(Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doRemove(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doRemove(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doRetrieve(Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doRetrieve(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doRetrieve(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doSend(Message<?>, long) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Subclasses must implement this method.
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.FluxMessageChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.PriorityChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.QueueChannel
 
doSend(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
doSend(Message<?>, long) - Method in class org.springframework.integration.jms.AbstractJmsChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
doSetConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
doSetRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
doSetWebServiceTemplate(WebServiceTemplate) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
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
 
doStart() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
Subclasses must implement this method with the start behavior.
doStart() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
doStart() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
doStart() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Take no action by default.
doStart() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
doStart() - Method in class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
 
doStart() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
doStart() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
doStart() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
doStart() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
doStart() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
doStart() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
doStart() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
doStart() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
doStart() - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
 
doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
Protected by lifecycleLock
doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
doStart() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
doStart() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
doStart() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
doStart() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
doStart() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
doStart() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Registers the notification listener with the specified ObjectNames.
doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
doStart() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
doStart() - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
 
doStart() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
doStart() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
doStart() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
doStart() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
 
doStart() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
doStart() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
doStart() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
 
doStart() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
 
doStart() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
doStart() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
doStart() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
doStart() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
doStart() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
doStart() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
doStart() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
doStart() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
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
 
doStop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
Stop the component and invoke callback.
doStop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
Subclasses must implement this method with the stop behavior.
doStop() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
doStop() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
doStop() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Take no action by default.
doStop() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
doStop() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
doStop() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
doStop() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
doStop() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
doStop() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
doStop() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
doStop() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
doStop() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
doStop() - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
 
doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
doStop() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
doStop() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
doStop() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
doStop() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
doStop() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Unregisters the notification listener.
doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
doStop() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
doStop() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
doStop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
doStop() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
doStop() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
doStop() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
doStop() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
doStop() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
doStop() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
doStop() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
doStore(Object, Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doStore(Object, Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doStore(Object, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doTransform(Message<?>) - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
 
doTransform(Message) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
doTransform(Message) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
Subclasses must implement this method to provide the transformation logic.
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.DecodingTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.StreamTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
doWhileLocked() - Method in class org.springframework.integration.util.WhileLockedProcessor
 
doWithClient(C) - Method in interface org.springframework.integration.file.remote.ClientCallback
Called within the context of a Session.
doWithClient(C) - Method in interface org.springframework.integration.file.remote.ClientCallbackWithoutResult
 
doWithClientWithoutResult(C) - Method in interface org.springframework.integration.file.remote.ClientCallbackWithoutResult
Called within the context of a session.
doWithInputStream(InputStream) - Method in interface org.springframework.integration.file.remote.InputStreamCallback
Called with the InputStream for the remote file.
doWithMessage(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
 
doWithMessageInternal(WebServiceMessage, Object) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
 
doWrite(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
Method that actually does the write.
drainTo(Collection<? super Message<?>>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
drainTo(Collection<? super Message<?>>, int) - Method in class org.springframework.integration.store.MessageGroupQueue
 
DslIntegrationConfigurationInitializer - Class in org.springframework.integration.dsl.context
The Java DSL Integration infrastructure beanFactory initializer.
DslIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.dsl.context.DslIntegrationConfigurationInitializer
 
duplicate(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
Return the duplicate header.
DUPLICATE - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
DUPLICATE_MESSAGE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
DUPS_OK_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
DUPS_OK_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
durableSubscriptionName(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
durableSubscriptionName(String) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
 
dynamicChannelLimit(int) - Method in class org.springframework.integration.dsl.RouterSpec
Set a limit for how many dynamic channels are retained (for reporting purposes).
DynamicExpression - Class in org.springframework.integration.expression
An implementation of Expression that delegates to an ExpressionSource for resolving the actual Expression instance per-invocation at runtime.
DynamicExpression(String, ExpressionSource) - Constructor for class org.springframework.integration.expression.DynamicExpression
 
DynamicJmsTemplate - Class in org.springframework.integration.jms
 
DynamicJmsTemplate() - Constructor for class org.springframework.integration.jms.DynamicJmsTemplate
 
DynamicPeriodicTrigger - Class in org.springframework.integration.util
This is a dynamically changeable Trigger.
DynamicPeriodicTrigger(long) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
Create a trigger with the given period in milliseconds.
DynamicPeriodicTrigger(Duration) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
Create a trigger with the provided duration.

E

EmbeddedJsonHeadersMessageMapper - Class in org.springframework.integration.support.json
For outbound messages, uses a message-aware Jackson object mapper to render the message as JSON.
EmbeddedJsonHeadersMessageMapper() - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds all headers, using the default JSON Object mapper.
EmbeddedJsonHeadersMessageMapper(String...) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds headers matching the supplied patterns, using the default JSON object mapper.
EmbeddedJsonHeadersMessageMapper(ObjectMapper) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds all headers, using the supplied JSON object mapper.
EmbeddedJsonHeadersMessageMapper(ObjectMapper, String...) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds headers matching the supplied patterns using the supplied JSON object mapper.
embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
EnableIntegration - Annotation Type in org.springframework.integration.config
The main configuration annotation to enable Spring Integration infrastructure: - Registers some built-in beans; - Adds several BeanFactoryPostProcessors; - Adds several BeanPostProcessors; - Adds annotations processors.
EnableIntegrationGraphController - Annotation Type in org.springframework.integration.http.config
Enables the IntegrationGraphController if org.springframework.web.servlet.DispatcherServlet or org.springframework.web.reactive.DispatcherHandler is present in the classpath.
EnableIntegrationManagement - Annotation Type in org.springframework.integration.config
Enables default configuring of management in Spring Integration components in an existing application.
EnableIntegrationMBeanExport - Annotation Type in org.springframework.integration.jmx.config
Enables default exporting for Spring Integration components in an existing application, as well as well all @ManagedResource annotated beans.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Set whether to automatically (default) or manually add a TcpListener to the connections created by this factory.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Set whether or not automatic or manual registration of the TcpListener is to be used.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
EnableMessageHistory - Annotation Type in org.springframework.integration.config
Enables MessageHistory for Integration components.
EnablePublisher - Annotation Type in org.springframework.integration.config
Provides the registration for the PublisherAnnotationBeanPostProcessor to allow the use of the Publisher annotation.
enableStatusReader(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
This field control the stderr events.
encode(Object, OutputStream) - Method in interface org.springframework.integration.codec.Codec
Encode (encode) an object to an OutputStream
encode(Object) - Method in interface org.springframework.integration.codec.Codec
Encode an object to a byte array
encode(Object, OutputStream) - Method in class org.springframework.integration.codec.CompositeCodec
 
encode(Object) - Method in class org.springframework.integration.codec.CompositeCodec
 
encode(Object, OutputStream) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
encode(Object) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
encode(Map<String, Object>, byte[]) - Method in class org.springframework.integration.websocket.support.ClientStompEncoder
 
encodeUri(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
encoding(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
 
encoding(Codec) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the EncodingPayloadTransformer.
encodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a DefaultUriBuilderFactory.EncodingMode for uri construction.
encodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Specify a DefaultUriBuilderFactory.EncodingMode for uri construction.
EncodingPayloadTransformer<T> - Class in org.springframework.integration.transformer
AbstractPayloadTransformer that delegates to a codec to encode the payload into a byte[].
EncodingPayloadTransformer(Codec) - Constructor for class org.springframework.integration.transformer.EncodingPayloadTransformer
 
end(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
If true, tail from the end of the file, otherwise include all lines from the beginning.
endpointFactoryBean - Variable in class org.springframework.integration.dsl.EndpointSpec
 
EndpointId - Annotation Type in org.springframework.integration.annotation
When used alongside an EIP annotation (and no @Bean), specifies the bean name of the consumer bean with the handler bean being id.handler (for a consuming endpoint) or id.source for a message source (e.g.
endpointIdValue(Method) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Return the EndpointId.value() property, if present.
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
 
EndpointNode - Class in org.springframework.integration.graph
Base class for all endpoints.
EndpointNode(int, String, Object, String) - Constructor for class org.springframework.integration.graph.EndpointNode
 
ENDPOINTS_NO_AUTO_STARTUP - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of AbstractEndpoint.autoStartup.
EndpointSpec<S extends EndpointSpec<S,F,H>,F extends BeanNameAware,H> - Class in org.springframework.integration.dsl
An IntegrationComponentSpec for endpoints.
EndpointSpec(H) - Constructor for class org.springframework.integration.dsl.EndpointSpec
 
EndpointUtils - Class in org.springframework.integration.amqp.support
Utility methods for messaging endpoints.
enhanceNameWithSubDirectory(F, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
enhanceNameWithSubDirectory(FTPFile, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
enhanceNameWithSubDirectory(ChannelSftp.LsEntry, String) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
enrich(Consumer<EnricherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ContentEnricher to the current integration flow position with provided options.
EnricherParser - Class in org.springframework.integration.config.xml
Parser for the 'enricher' element.
EnricherParser() - Constructor for class org.springframework.integration.config.xml.EnricherParser
 
EnricherSpec - Class in org.springframework.integration.dsl
EnricherSpec() - Constructor for class org.springframework.integration.dsl.EnricherSpec
 
enrichHeaders(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
enrichHeaders(MapBuilder<?, String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
enrichHeaders(Map<String, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(Map<String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(Consumer<HeaderEnricherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher as the result of provided Consumer.
entityClass(Class<?>) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify the class type which is being used for retrieving entities from the database.
entityClass(Class<?>) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify the class type which is being used for retrieving entities from the database.
entityClass(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
The fully qualified name of the entity class to be passed to find(..) or findOne(..) method in MongoOperations.
entityClass(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Entry() - Constructor for class org.springframework.integration.history.MessageHistory.Entry
 
entrySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
equals(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
equals(Object) - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
equals(Object) - Method in exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
equals(Object) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
equals(Object) - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
equals(Object) - Method in class org.springframework.integration.message.AdviceMessage
 
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
equals(Object) - Method in class org.springframework.integration.support.MutableMessage
 
equals(Object) - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
equals(Object) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
equalsResult(Supplier<U>) - Static method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
EqualsResultMatcher<U> - Class in org.springframework.integration.test.matcher
A matcher that evaluates against the result of invoking a function, wrapped by the Supplier The goal is to defer the computation until the matcher needs to be actually evaluated.
EqualsResultMatcher(Supplier<U>) - Constructor for class org.springframework.integration.test.matcher.EqualsResultMatcher
 
ERROR_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ERROR_LOGGER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ErrorCapableCompositeMessageHandlerNode - Class in org.springframework.integration.graph
Represents a composite message handler that can emit error messages (pollable endpoint).
ErrorCapableCompositeMessageHandlerNode(int, String, CompositeMessageHandler, String, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.graph.ErrorCapableCompositeMessageHandlerNode
 
ErrorCapableDiscardingMessageHandlerNode - Class in org.springframework.integration.graph
Represents an endpoint that has a discard channel and can emit errors (pollable endpoint).
ErrorCapableDiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableDiscardingMessageHandlerNode
 
ErrorCapableEndpointNode - Class in org.springframework.integration.graph
Represents nodes that can natively handle errors.
ErrorCapableEndpointNode(int, String, Object, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableEndpointNode
 
ErrorCapableMessageHandlerNode - Class in org.springframework.integration.graph
Represents a message handler that can produce errors (pollable).
ErrorCapableMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableMessageHandlerNode
 
ErrorCapableNode - Interface in org.springframework.integration.graph
Nodes implementing this interface are capable of emitting errors.
ErrorCapableRoutingNode - Class in org.springframework.integration.graph
Represents an endpoint that can route to multiple channels and can emit errors (pollable endpoint).
ErrorCapableRoutingNode(int, String, MessageHandler, String, String, String, Collection<String>) - Constructor for class org.springframework.integration.graph.ErrorCapableRoutingNode
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
errorChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set an error channel.
errorChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set an error channel.
errorChannel(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies a channel that error messages will be sent to if a failure occurs in the gateway's proxy invocation.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies a channel that error messages will be sent to if a failure occurs in the gateway's proxy invocation.
errorChannel(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header: bean name or instance.
errorChannel(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header: bean name or instance.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the MessageChannel to which error messages will be sent.
errorChannel(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the bean name of the MessageChannel to which error messages will be sent.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
An error channel to use.
errorChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
An error channel name to use.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a MessageChannel to use for sending error message in case of polling failures.
errorChannel(String) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a bean name for the MessageChannel to use for sending error message in case of polling failures.
errorChannel(String) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a MessageChannel bean name for async error processing.
errorChannel(MessageChannel) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
errorChannelExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is a SpEL Expression evaluation result.
errorChannelExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is a SpEL Expression evaluation result.
errorChannelFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is obtained by invoking the Function callback.
errorChannelFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is obtained by invoking the Function callback.
errorCode(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
The error code to use to signal an error in the message handling.
errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.PollerSpec
Specify the ErrorHandler to wrap a taskExecutor to the ErrorHandlingTaskExecutor.
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
errorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
Set the ResponseErrorHandler for the underlying RestTemplate.
errorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
errorHandler(GenericErrorHandler<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Specify an ErrorHandler for the AbstractMessageListenerContainer.
ErrorHandlingTaskExecutor - Class in org.springframework.integration.util
A TaskExecutor implementation that wraps an existing Executor instance in order to catch any exceptions.
ErrorHandlingTaskExecutor(Executor, ErrorHandler) - Constructor for class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
ErrorMessageExceptionTypeRouter - Class in org.springframework.integration.router
A Message Router that resolves the target MessageChannel for messages whose payload is a Throwable.
ErrorMessageExceptionTypeRouter() - Constructor for class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
ErrorMessageExceptionTypeRouterParser - Class in org.springframework.integration.config.xml
Parser for the <exception-type-router/> element.
ErrorMessageExceptionTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
ErrorMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the ErrorMessage.
ErrorMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
 
errorMessagePayload(Message, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
Return an ListenerExecutionFailedException or a ManualAckListenerExecutionFailedException depending on whether isManualAck is false or true.
errorMessagePayload(List<Message>, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
Return an ListenerExecutionFailedException or a ManualAckListenerExecutionFailedException depending on whether isManualAck is false or true.
ErrorMessagePublisher - Class in org.springframework.integration.core
The component which can be used as general purpose of errors publishing.
ErrorMessagePublisher() - Constructor for class org.springframework.integration.core.ErrorMessagePublisher
 
ErrorMessageSendingRecoverer - Class in org.springframework.integration.handler.advice
A RecoveryCallback that sends the final throwable as an ErrorMessage after retry exhaustion.
ErrorMessageSendingRecoverer() - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance with the default errorChannel to publish recovery error message.
ErrorMessageSendingRecoverer(MessageChannel) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance based on the provided message channel.
ErrorMessageSendingRecoverer(MessageChannel, ErrorMessageStrategy) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance based on the provided message channel and ErrorMessageStrategy.
ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException - Exception in org.springframework.integration.handler.advice
 
errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Set the error message strategy to use for returned (or negatively confirmed) messages.
errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
ErrorMessageStrategy - Interface in org.springframework.integration.support
A strategy to build an ErrorMessage based on the provided Throwable and AttributeAccessor as a context.
ErrorMessageUtils - Class in org.springframework.integration.support
Utilities for building error messages.
errorOnTimeout(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
If errorOnTimeout is true, construct an instance that will send an ErrorMessage with a MessageTimeoutException payload to the error channel if a reply is expected but none is received.
ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
errorsKey(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
The key used to expose Errors in the core, in the case that message handling fails.
escapeRegexSpecials(String) - Static method in class org.springframework.integration.ip.util.RegexUtils
Escapes (precedes with \) any characters in the parameter in the set
ETX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
evaluate(Expression) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
 
evaluate(Expression) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.EvaluationCallback
 
evaluate(Object, String, Predicate...) - Static method in class org.springframework.integration.json.JsonPathUtils
 
evaluate(Object, String, Object...) - Static method in class org.springframework.integration.xml.xpath.XPathUtils
Utility method to evaluate an xpath on the provided object.
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
 
evaluateExpression(Expression, Message<?>, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(String, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(String, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateHttpStatus(HttpEntity<?>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
evaluatePayloadExpression(Object) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
evaluateRemoteDirectory() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
evaluateTypeFromExpression(Message<?>, Expression, String) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
evaluateXPath(XPathExpression, Node) - Method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
 
EventDrivenConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a SubscribableChannel.
EventDrivenConsumer(SubscribableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
 
EventInboundChannelAdapterParser - Class in org.springframework.integration.event.config
 
EventInboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventInboundChannelAdapterParser
 
EventNamespaceHandler - Class in org.springframework.integration.event.config
Namespace handler for Spring Integration's 'event' namespace.
EventNamespaceHandler() - Constructor for class org.springframework.integration.event.config.EventNamespaceHandler
 
EventOutboundChannelAdapterParser - Class in org.springframework.integration.event.config
 
EventOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
 
EventType - Enum in org.springframework.integration.gemfire.inbound
Enumeration of GemFire event types.
exceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
exchange(FanoutExchange) - Method in class org.springframework.integration.amqp.dsl.AmqpPublishSubscribeMessageChannelSpec
 
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
exchange(Message<?>) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
 
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.
execute(SessionCallback<F, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Execute the callback's doInSession method after obtaining a session.
execute(SessionCallback<F, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
execute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
Call this for a normal invocation.proceed().
execute(MessageGroupStore, MessageGroup) - Method in interface org.springframework.integration.store.MessageGroupStore.MessageGroupCallback
 
execute(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
Execute using the primary executor.
execute(Runnable) - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
execute2(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
Execute using the secondary executor.
executeOutboundJpaOperation(Message<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute the actual Jpa Operation.
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Subclasses must implement this method.
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in interface org.springframework.integration.scripting.ScriptExecutor
Execute a script from the provided ScriptSource with an optional binding variables.
executeScript(ScriptSource) - Method in interface org.springframework.integration.scripting.ScriptExecutor
Execute a script from the provided ScriptSource
executeStoredProcedure() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Execute a Stored Procedure or Function - Use when no Message is available to extract ProcedureParameter values from it.
executeStoredProcedure(Message<?>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Execute a Stored Procedure or Function - Use with Message is available to extract ProcedureParameter values from it.
executeUpdate(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdate(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the given update statement and uses the given parameter source to set the required query parameters.
executeUpdateQuery(Message<?>, boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
executeUpdateWithNamedQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdateWithNamedQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
executeUpdateWithNativeQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdateWithNativeQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
executeWithClient(ClientCallback<C, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Execute the callback's doWithClient method after obtaining a session's client, providing access to low level methods.
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
 
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
 
executor - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
executor(Executor) - Method in class org.springframework.integration.dsl.Channels
 
executor(String, Executor) - Method in class org.springframework.integration.dsl.Channels
 
executor(Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
executor(String, Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
ExecutorChannel - Class in org.springframework.integration.channel
An implementation of MessageChannel that delegates to an instance of UnicastingDispatcher which in turn delegates all dispatching invocations to an Executor.
ExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.ExecutorChannel
Create an ExecutorChannel that delegates to the provided Executor when dispatching Messages.
ExecutorChannel(Executor, LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.ExecutorChannel
Create an ExecutorChannel with a LoadBalancingStrategy that delegates to the provided Executor when dispatching Messages.
ExecutorChannelInterceptorAware - Interface in org.springframework.integration.channel
The InterceptableChannel extension for the cases when the ExecutorChannelInterceptors may have reason (e.g.
ExecutorChannelSpec - Class in org.springframework.integration.dsl
 
ExecutorChannelSpec(Executor) - Constructor for class org.springframework.integration.dsl.ExecutorChannelSpec
 
executorInterceptorsSize - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
exists(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Check if a file exists on the remote server.
exists(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
exists(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
exists(String) - Method in interface org.springframework.integration.file.remote.session.Session
Check if the remote file or directory exists.
exists(String) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
This particular FTP implementation is based on the FTPClient.getStatus(String) by default, but since not all FTP servers properly implement the STAT command, the framework internal FtpRemoteFileTemplate instances are switched to the FTPClient.listNames(String) for only files operations.
exists(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
exists(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
expect(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
expectedResponseType(Class<?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify the expected response type for the REST request.
expectedResponseType(ParameterizedTypeReference<?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a ParameterizedTypeReference for the expected response type for the REST request.
expectedResponseType(Class<?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the expected response type for the RSocket response.
expectedResponseType(Function<Message<P>, ?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the Function to determine the type for the RSocket response.
expectedResponseType(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the Expression to determine the type for the RSocket response.
expectedResponseType(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify an Expression to determine the type for the RSocket response.
expectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a SpEL Expression to determine the type for the expected response The returned value of the expression could be an instance of Class or String representing a fully qualified class name.
expectedResponseTypeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a Function to determine the type for the expected response The returned value of the expression could be an instance of Class or String representing a fully qualified class name.
expectReply - Variable in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
 
expectReply(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
expectReply(boolean) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
expectSingleResult(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
This parameter indicates that only one result object shall be returned as a result from the executed JPA operation.
expectSingleResult(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
This parameter indicates that only one result object shall be returned as a result from the executed JPA operation.
expectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
This parameter indicates that only one result object will be returned from the database by using a findOne query.
expectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Allow you to manage which find* method to invoke on ReactiveMongoOperations.
expectSingleResult(boolean) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
The flag to manage which find* method to invoke on R2dbcEntityOperations.
ExpirableLockRegistry - Interface in org.springframework.integration.support.locks
A LockRegistry implementing this interface supports the removal of aged locks that are not currently locked.
EXPIRATION_DATE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
expirationDate(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
expirationDate(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
expirationDateExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is a SpEL Expression evaluation result.
expirationDateExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is a SpEL Expression evaluation result.
expirationDateFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is obtained by invoking the Function callback.
expirationDateFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is obtained by invoking the Function callback.
expireGroup(Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
expireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.dsl.AggregatorSpec
 
expireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Expire (completely remove) a group if it is completed due to timeout.
expireMessageGroups(long) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
expireMessageGroups(long) - Method in interface org.springframework.integration.store.MessageGroupStore
Extract all expired groups (whose timestamp is older than the current time less the threshold provided) and call each of the registered callbacks on them in turn.
expireUnusedOlderThan(long) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
expireUnusedOlderThan(long) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
 
expireUnusedOlderThan(long) - Method in interface org.springframework.integration.support.locks.ExpirableLockRegistry
Remove locks last acquired more than 'age' ago that are not currently locked.
expireUnusedOlderThan(long) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Remove locks last acquired more than 'age' ago that are not currently locked.
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
explicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
exposedHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
List of response headers that the user-agent will allow the client to access.
exposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.context.IntegrationObjectSupport
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.util.AbstractExpressionEvaluator
 
ExpressionArgumentsStrategy - Class in org.springframework.integration.redis.outbound
 
ExpressionArgumentsStrategy(String[]) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
ExpressionArgumentsStrategy(String[], boolean) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
ExpressionCapable - Interface in org.springframework.integration.context
Components that implement this interface are capable of supporting a primary SpEL expression as part of their configuration.
ExpressionCommandMessageProcessor - Class in org.springframework.integration.handler
A MessageProcessor implementation that expects an Expression or expressionString as the Message payload.
ExpressionCommandMessageProcessor() - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionCommandMessageProcessor(MethodFilter) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionCommandMessageProcessor(MethodFilter, BeanFactory) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionControlBusFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating MessageHandler instances to handle a message as a SpEL expression.
ExpressionControlBusFactoryBean() - Constructor for class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
ExpressionEvalMap - Class in org.springframework.integration.expression
An immutable AbstractMap implementation that wraps a Map<String, Object>, where values must be instances of String or Expression, and evaluates an expression for the provided key from the underlying original Map.
ExpressionEvalMap.ComponentsEvaluationCallback - Class in org.springframework.integration.expression
The ExpressionEvalMap.EvaluationCallback implementation which evaluates an expression using the provided context, root and returnType variables.
ExpressionEvalMap.EvaluationCallback - Interface in org.springframework.integration.expression
Implementations of this interface can be provided to build 'on demand ExpressionEvalMap.get(Object) logic' for ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapBuilder - Class in org.springframework.integration.expression
The builder class to instantiate ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapComponentsBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvalMap.ExpressionEvalMapFinalBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvaluatingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that evaluates an expression.
ExpressionEvaluatingCorrelationStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
ExpressionEvaluatingCorrelationStrategy(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
ExpressionEvaluatingHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
ExpressionEvaluatingHeaderValueMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
Create a header value processor for the given Expression and the expected type of the expression evaluation result.
ExpressionEvaluatingHeaderValueMessageProcessor(String, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
Create a header value processor for the given expression string and the expected type of the expression evaluation result.
ExpressionEvaluatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
A MessageGroupProcessor implementation that evaluates a SpEL expression.
ExpressionEvaluatingMessageGroupProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
ExpressionEvaluatingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that evaluates the provided Expression expecting a void return.
ExpressionEvaluatingMessageHandler(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
ExpressionEvaluatingMessageListProcessor - Class in org.springframework.integration.aggregator
A base class for aggregators that evaluates a SpEL expression with the message list as the root object within the evaluation context.
ExpressionEvaluatingMessageListProcessor(String, Class<?>) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageListProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageListProcessor(Expression, Class<?>) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided expression and expected result type.
ExpressionEvaluatingMessageListProcessor(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided expression.
ExpressionEvaluatingMessageProcessor<T> - Class in org.springframework.integration.handler
A MessageProcessor implementation that evaluates a SpEL expression with the Message itself as the root object within the evaluation context.
ExpressionEvaluatingMessageProcessor(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression.
ExpressionEvaluatingMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression and expected type for its evaluation result.
ExpressionEvaluatingMessageProcessor(String) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression.
ExpressionEvaluatingMessageProcessor(String, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Construct ExpressionEvaluatingMessageProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageSource<T> - Class in org.springframework.integration.endpoint
 
ExpressionEvaluatingMessageSource(Expression, Class<T>) - Constructor for class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
ExpressionEvaluatingParameterSource(Object, List<JpaParameter>, ExpressionEvaluatingParameterSourceUtils.ParameterExpressionEvaluator) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
ExpressionEvaluatingParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
A SpEL expression based ParameterSourceFactory implementation.
ExpressionEvaluatingParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingParameterSourceFactory(BeanFactory) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource - Class in org.springframework.integration.jpa.support.parametersource
 
ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that evaluates an expression.
ExpressionEvaluatingReleaseStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
ExpressionEvaluatingReleaseStrategy(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
ExpressionEvaluatingRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
Used to advise MessageHandlers.
ExpressionEvaluatingRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException - Exception in org.springframework.integration.handler.advice
 
ExpressionEvaluatingRouter - Class in org.springframework.integration.router
A Message Router implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingRouter(String) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
Construct an instance by parsing the supplied expression string.
ExpressionEvaluatingRouter(Expression) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
Construct an instance with the supplied Expression.
ExpressionEvaluatingRoutingSlipRouteStrategy - Class in org.springframework.integration.routingslip
The Expression based RoutingSlipRouteStrategy implementation.
ExpressionEvaluatingRoutingSlipRouteStrategy(String) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy(Expression) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply - Class in org.springframework.integration.routingslip
 
ExpressionEvaluatingSelector - Class in org.springframework.integration.filter
A MessageSelector implementation that evaluates a SpEL expression.
ExpressionEvaluatingSelector(String) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSelector(Expression) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingSplitter(Expression) - Constructor for class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
 
ExpressionEvaluatingSqlParameterSourceFactory - Class in org.springframework.integration.jdbc
An implementation of SqlParameterSourceFactory which creates an SqlParameterSource that evaluates Spring EL expressions.
ExpressionEvaluatingSqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
 
ExpressionEvaluatingTransactionSynchronizationProcessor - Class in org.springframework.integration.transaction
This implementation of TransactionSynchronizationFactory allows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - see TransactionSynchronization.
ExpressionEvaluatingTransactionSynchronizationProcessor() - Constructor for class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
ExpressionEvaluatingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingTransformer(Expression) - Constructor for class org.springframework.integration.transformer.ExpressionEvaluatingTransformer
 
ExpressionFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating Expression instances.
ExpressionFactoryBean(String) - Constructor for class org.springframework.integration.config.ExpressionFactoryBean
 
ExpressionFileListFilter<F> - Class in org.springframework.integration.file.filters
A SpEL expression based AbstractFileListFilter implementation.
ExpressionFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.ExpressionFileListFilter
 
ExpressionFileListFilter(Expression) - Constructor for class org.springframework.integration.file.filters.ExpressionFileListFilter
 
ExpressionMessageProducerSupport - Class in org.springframework.integration.endpoint
A MessageProducerSupport sub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.
ExpressionMessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
ExpressionSource - Interface in org.springframework.integration.expression
Strategy interface for retrieving Expressions.
expressionToFile(Expression, EvaluationContext, Message<?>, String) - Static method in class org.springframework.integration.expression.ExpressionUtils
Evaluate an expression and return a File object; the expression can evaluate to a String or File.
ExpressionUtils - Class in org.springframework.integration.expression
Utility class with static methods for helping with evaluation of SpEL expressions.
EXPUNGED - Static variable in class org.springframework.integration.mail.MailHeaders
 
externalReceiver - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
externalReceiver - Variable in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
extract(ClientHttpResponse, BodyExtractor.Context) - Method in class org.springframework.integration.webflux.support.ClientHttpResponseBodyExtractor
 
extractAdviceChain(String, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
extractBody(boolean) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Configure a flag to extract body from a change event or use event as a payload.
extractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
extractPayload(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
Configure whether normal spring-messaging to AMQP message mapping is enabled.
extractPayload(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify whether the outbound message's payload should be extracted when preparing the request body.
extractPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
 
extractPayload() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
If true will extract the payload as the parameter for validateResponse()
extractPayload() - Method in class org.springframework.integration.test.support.MessageValidator
 
extractPayload() - Method in class org.springframework.integration.test.support.PayloadValidator
 
extractPayload - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
extractPayload - Variable in class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
 
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
Specify true to extract the payloadSource from the request or use the entire request as the payload; default true.
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
Specify a flag to return the whole WebServiceMessage or build the payload based on WebServiceMessage and populated headers according headerMapper configuration.
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify a flag to return the whole WebServiceMessage or build the payload based on WebServiceMessage and populated headers according headerMapper configuration.
extractProxyTarget(Object) - Static method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify whether only the reply Message's payload should be passed in the response.
extractReplyPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
extractRequestBody(ServletServerHttpRequest) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
extractStandardHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
Extract "standard" headers from an AMQP MessageProperties instance.
extractStandardHeaders(Message) - Static method in class org.springframework.integration.mail.support.MailUtils
Map the message headers to a Map using MailHeaders keys; specifically maps the address headers and the subject.
extractStandardHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the standard headers from the specified source.
extractStandardHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractStandardHeaders(Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
extractTypeIfPossible(Object, Class<H>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
extractTypeIfPossible(Object, Class<T>) - Static method in class org.springframework.integration.context.IntegrationObjectSupport
 
extractUserDefinedHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
Extract user-defined headers from an AMQP MessageProperties instance.
extractUserDefinedHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the user-defined headers from the specified source.
extractUserDefinedHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractUserDefinedHeaders(Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 

F

FACILITY - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
FACILITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
FAILED_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
The context key for the message object.
failedDeclarationRetryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Set the interval between passive queue declaration attempts in milliseconds.
failover - Variable in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
failover(Boolean) - Method in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
FailoverClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Given a list of connection factories, serves up TcpConnections that can iterate over a connection from each factory until the write succeeds or the list is exhausted.
FailoverClientConnectionFactory(List<AbstractClientConnectionFactory>) - Constructor for class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
Construct an instance with the provided delegate factories.
FATAL_WHEN_NO_BEANFACTORY - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
Should be set to TRUE on CI plans and framework developer systems.
faultMessageResolver - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
faultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Specify the FaultMessageResolver to use.
faultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify the FaultMessageResolver to use.
Feed - Class in org.springframework.integration.feed.dsl
The Spring Integration Feed components Factory.
FeedEntryMessageSource - Class in org.springframework.integration.feed.inbound
This implementation of MessageSource will produce individual SyndEntrys for a feed identified with the 'feedUrl' attribute.
FeedEntryMessageSource(URL, String) - Constructor for class org.springframework.integration.feed.inbound.FeedEntryMessageSource
Creates a FeedEntryMessageSource that will use a HttpURLFeedFetcher to read feeds from the given URL.
FeedEntryMessageSource(Resource, String) - Constructor for class org.springframework.integration.feed.inbound.FeedEntryMessageSource
Creates a FeedEntryMessageSource that will read feeds from the given Resource.
FeedEntryMessageSourceSpec - Class in org.springframework.integration.feed.dsl
FeedEntryMessageSourceSpec(URL, String) - Constructor for class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
 
FeedEntryMessageSourceSpec(Resource, String) - Constructor for class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
 
FeedInboundChannelAdapterParser - Class in org.springframework.integration.feed.config
Handles parsing the configuration for the feed inbound-channel-adapter.
FeedInboundChannelAdapterParser() - Constructor for class org.springframework.integration.feed.config.FeedInboundChannelAdapterParser
 
FeedNamespaceHandler - Class in org.springframework.integration.feed.config
NamespaceHandler for the feed module.
FeedNamespaceHandler() - Constructor for class org.springframework.integration.feed.config.FeedNamespaceHandler
 
fetchMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Fetches the specified messages from this receiver's folder.
file(File) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
FileCopyingMultipartFileReader - Class in org.springframework.integration.http.multipart
MultipartFileReader implementation that copies the MultipartFile's content to a new temporary File in the specified directory.
FileCopyingMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Create a FileCopyingMultipartFileReader that creates temporary Files in the default temporary directory.
FileCopyingMultipartFileReader(File) - Constructor for class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Create a FileCopyingMultipartFileReader that creates temporary Files in the given directory.
fileDelay(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
The delay in milliseconds between attempts to tail a non-existent file, or between attempts to execute a process if it fails for any reason.
fileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the FileExistsMode that specifies what will happen in case the destination exists.
fileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Determine the action to take when using GET and MGET operations when the file already exists locally, or PUT and MPUT when the file exists on the remote system.
FileExistsMode - Enum in org.springframework.integration.file.support
When writing file, this enumeration indicates what action shall be taken in case the destination file already exists.
fileFilters - Variable in class org.springframework.integration.file.filters.CompositeFileListFilter
 
FileHeaders - Class in org.springframework.integration.file
Pre-defined header names to be used when storing or retrieving File-related values to/from integration Message Headers.
FileHeaders() - Constructor for class org.springframework.integration.file.FileHeaders
 
FileInboundChannelAdapterParser - Class in org.springframework.integration.file.config
Parser for the <inbound-channel-adapter> element of the 'file' namespace.
FileInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileInboundChannelAdapterParser
 
FileInboundChannelAdapterSpec - Class in org.springframework.integration.file.dsl
FileInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
 
FileInboundChannelAdapterSpec(Comparator<File>) - Constructor for class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
 
FileInfo<F> - Interface in org.springframework.integration.file.remote
Represents a remote file info - an abstraction over the underlying implementation.
FileIntegrationEvent - Class in org.springframework.integration.file.event
 
FileIntegrationEvent(Object) - Constructor for class org.springframework.integration.file.event.FileIntegrationEvent
 
FileKryoRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar used to validateRegistration a File serializer.
FileKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
FileKryoRegistrar(int) - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
FileListFilter<F> - Interface in org.springframework.integration.file.filters
Strategy interface for filtering a group of files.
FileListFilterFactoryBean - Class in org.springframework.integration.file.config
 
FileListFilterFactoryBean() - Constructor for class org.springframework.integration.file.config.FileListFilterFactoryBean
 
fileListFilterFactoryBean - Variable in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
 
FileLocker - Interface in org.springframework.integration.file
A FileLocker is a strategy that can ensure that files are only processed a single time.
FileMarker() - Constructor for class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
FileMarker(String, FileSplitter.FileMarker.Mark, long) - Constructor for class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
FILENAME - Static variable in class org.springframework.integration.file.FileHeaders
 
fileName(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
fileName(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
 
fileName(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
 
fileName(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
 
fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the DefaultFileNameGenerator based on the provided SpEL expression.
fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the DefaultFileNameGenerator based on the provided SpEL expression.
fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file name expression to determine the full path to the remote file.
fileNameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file name expression to determine the full path to the remote file.
fileNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file name function to determine the full path to the remote file.
fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the file name generator used to generate the target file name.
fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
FileNameGenerator - Interface in org.springframework.integration.file
Strategy interface for generating a file name from a message.
FileNamespaceHandler - Class in org.springframework.integration.file.config
Namespace handler for Spring Integration's 'file' namespace.
FileNamespaceHandler() - Constructor for class org.springframework.integration.file.config.FileNamespaceHandler
 
fileNotFound() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
FileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
Parser for the <outbound-channel-adapter/> element of the 'file' namespace.
FileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
 
FileOutboundGatewayParser - Class in org.springframework.integration.file.config
Parser for the 'outbound-gateway' element of the file namespace.
FileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.FileOutboundGatewayParser
 
FileParserUtils - Class in org.springframework.integration.file.config
 
FileReadingMessageSource - Class in org.springframework.integration.file
MessageSource that creates messages from a file system directory.
FileReadingMessageSource() - Constructor for class org.springframework.integration.file.FileReadingMessageSource
Creates a FileReadingMessageSource with a naturally ordered queue of unbounded capacity.
FileReadingMessageSource(int) - Constructor for class org.springframework.integration.file.FileReadingMessageSource
Creates a FileReadingMessageSource with a bounded queue of the given capacity.
FileReadingMessageSource(Comparator<File>) - Constructor for class org.springframework.integration.file.FileReadingMessageSource
Creates a FileReadingMessageSource with a PriorityBlockingQueue ordered with the passed in Comparator.
FileReadingMessageSource.WatchEventType - Enum in org.springframework.integration.file
 
FileReadingMessageSourceFactoryBean - Class in org.springframework.integration.file.config
 
FileReadingMessageSourceFactoryBean() - Constructor for class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
fileRotated() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
Files - Class in org.springframework.integration.file.dsl
The Spring Integration File components Factory.
Files() - Constructor for class org.springframework.integration.file.dsl.Files
 
FileSerializer - Class in org.springframework.integration.codec.kryo
A custom Kryo Serializer for serializing File payloads.
FileSerializer() - Constructor for class org.springframework.integration.codec.kryo.FileSerializer
 
FileServerEvent - Class in org.springframework.integration.file.remote.server
Base class for file server events.
FileServerEvent(Object) - Constructor for class org.springframework.integration.file.remote.server.FileServerEvent
 
FileServerEvent(Object, Throwable) - Constructor for class org.springframework.integration.file.remote.server.FileServerEvent
 
FileSplitter - Class in org.springframework.integration.file.splitter
The AbstractMessageSplitter implementation to split the File Message payload to lines.
FileSplitter() - Constructor for class org.springframework.integration.file.splitter.FileSplitter
Construct a splitter where the FileSplitter.splitMessage(Message) method returns an iterator and the file is read line-by-line during iteration.
FileSplitter(boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
Construct a splitter where the FileSplitter.splitMessage(Message) method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
FileSplitter(boolean, boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
Construct a splitter where the FileSplitter.splitMessage(Message) method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
FileSplitter(boolean, boolean, boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
Construct a splitter where the FileSplitter.splitMessage(Message) method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
FileSplitter.FileMarker - Class in org.springframework.integration.file.splitter
 
FileSplitter.FileMarker.Mark - Enum in org.springframework.integration.file.splitter
 
FileSplitterParser - Class in org.springframework.integration.file.config
 
FileSplitterParser() - Constructor for class org.springframework.integration.file.config.FileSplitterParser
 
FileSplitterSpec - Class in org.springframework.integration.file.dsl
FileSplitterSpec() - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
 
FileSplitterSpec(boolean) - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
 
FileSplitterSpec(boolean, boolean) - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
 
fileStillExists(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Check if the file still exists; default implementation returns true.
fileStillExists(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
Check that the file still exists, to avoid a race condition when multi-threaded and another thread removed the file while we were waiting for the lock.
FileSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.file.filters
File system implementation of AbstractMarkerFilePresentFileListFilter.
FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>, String) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>, Function<String, String>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
FileSystemMarkerFilePresentFileListFilter(Map<FileListFilter<File>, Function<String, String>>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
FileSystemPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.file.filters
 
FileSystemPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
 
FileTailInboundChannelAdapterFactoryBean - Class in org.springframework.integration.file.config
 
FileTailInboundChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
FileTailInboundChannelAdapterParser - Class in org.springframework.integration.file.config
 
FileTailInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileTailInboundChannelAdapterParser
 
FileTailingEvent(Object, String, File) - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
 
FileTailingIdleEvent(Object, File, long) - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingIdleEvent
 
FileTailingMessageProducerSupport - Class in org.springframework.integration.file.tail
Base class for file tailing inbound adapters.
FileTailingMessageProducerSupport() - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
FileTailingMessageProducerSupport.FileTailingEvent - Class in org.springframework.integration.file.tail
 
FileTailingMessageProducerSupport.FileTailingIdleEvent - Class in org.springframework.integration.file.tail
 
FileToByteArrayTransformer - Class in org.springframework.integration.file.transformer
A payload transformer that copies a File's contents to a byte array.
FileToByteArrayTransformer() - Constructor for class org.springframework.integration.file.transformer.FileToByteArrayTransformer
 
FileToByteArrayTransformerParser - Class in org.springframework.integration.file.config
Parser for the <file-to-bytes-transformer> element.
FileToByteArrayTransformerParser() - Constructor for class org.springframework.integration.file.config.FileToByteArrayTransformerParser
 
FileToStringTransformer - Class in org.springframework.integration.file.transformer
A payload transformer that copies a File's contents to a String.
FileToStringTransformer() - Constructor for class org.springframework.integration.file.transformer.FileToStringTransformer
 
FileToStringTransformerParser - Class in org.springframework.integration.file.config
Parser for the <file-to-string-transformer> element.
FileToStringTransformerParser() - Constructor for class org.springframework.integration.file.config.FileToStringTransformerParser
 
FileTransferringMessageHandler<F> - Class in org.springframework.integration.file.remote.handler
A MessageHandler implementation that transfers files to a remote server.
FileTransferringMessageHandler(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
FileTransferringMessageHandler(RemoteFileTemplate<F>) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
FileTransferringMessageHandler(RemoteFileTemplate<F>, FileExistsMode) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
FileTransferringMessageHandlerSpec<F,S extends FileTransferringMessageHandlerSpec<F,S>> - Class in org.springframework.integration.file.dsl
FileTransferringMessageHandlerSpec() - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
FileTransferringMessageHandlerSpec(SessionFactory<F>) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>, FileExistsMode) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
FileUtils - Class in org.springframework.integration.file.support
Utilities for operations on Files.
FileWritingMessageHandler - Class in org.springframework.integration.file
A MessageHandler implementation that writes the Message payload to a file.
FileWritingMessageHandler(File) - Constructor for class org.springframework.integration.file.FileWritingMessageHandler
FileWritingMessageHandler(Expression) - Constructor for class org.springframework.integration.file.FileWritingMessageHandler
FileWritingMessageHandler.FlushPredicate - Interface in org.springframework.integration.file
When using FileExistsMode.APPEND_NO_FLUSH, an implementation of this interface is called for each file that has pending data to flush and close when FileWritingMessageHandler.flushIfNeeded(FlushPredicate) is invoked.
FileWritingMessageHandler.MessageFlushPredicate - Interface in org.springframework.integration.file
When using FileExistsMode.APPEND_NO_FLUSH an implementation of this interface is called for each file that has pending data to flush when a trigger message is received.
FileWritingMessageHandlerFactoryBean - Class in org.springframework.integration.file.config
Factory bean used to create FileWritingMessageHandlers.
FileWritingMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
FileWritingMessageHandlerSpec - Class in org.springframework.integration.file.dsl
FileWritingMessageHandlerSpec(File) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
FileWritingMessageHandlerSpec(String) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
FileWritingMessageHandlerSpec(Function<Message<P>, ?>) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
FileWritingMessageHandlerSpec(Expression) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
FileWrittenEvent - Class in org.springframework.integration.ftp.server
An event that is emitted when a file is written.
FileWrittenEvent(FtpSession, FtpRequest, boolean) - Constructor for class org.springframework.integration.ftp.server.FileWrittenEvent
 
FileWrittenEvent - Class in org.springframework.integration.sftp.server
An event that is emitted when a file is written.
FileWrittenEvent(Object, String, Path, int, Throwable) - Constructor for class org.springframework.integration.sftp.server.FileWrittenEvent
 
fillToCrLf(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
 
Filter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of playing the role of a Message Filter.
filter(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MessageSelector for the provided SpEL expression.
filter(String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MessageSelector for the provided SpEL expression.
filter(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the discovered method of the provided service.
filter(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the method of the provided service.
filter(Object, String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the method of the provided service.
filter(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
filter(MessageProcessorSpec<?>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
filter(Class<P>, GenericSelector<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(Class<P>, GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(GenericSelector<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(List<Method>) - Method in class org.springframework.integration.expression.ControlBusMethodFilter
 
filter(FileListFilter<File>) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Configure the filter.
filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a FileListFilter to be applied to the remote files before copying them.
filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set a FileListFilter to filter remote files.
filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Configure a FileListFilter to be applied to the remote files before copying them.
filter(Collection<T>) - Method in class org.springframework.integration.util.AcceptOnceCollectionFilter
 
filter(List<Method>) - Method in class org.springframework.integration.util.AnnotatedMethodFilter
 
filter(Collection<T>) - Method in interface org.springframework.integration.util.CollectionFilter
 
filter(List<Method>) - Method in class org.springframework.integration.util.FixedMethodFilter
 
FILTER_ATTRIBUTE - Static variable in class org.springframework.integration.file.config.FileParserUtils
 
filterAndCopyHeadersIfAbsent(Map<String, ?>, String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Remove headers from the provided map matching to the provided pattens and only after that copy the result into the target message headers.
FilterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Filter.
FilterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
 
FilterEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec implementation for the MessageFilter.
FilterEndpointSpec(MessageFilter) - Constructor for class org.springframework.integration.dsl.FilterEndpointSpec
 
filterExpression(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
FilterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Filter.
FilterFactoryBean() - Constructor for class org.springframework.integration.config.FilterFactoryBean
 
filterFiles(F[]) - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
 
filterFiles(F[]) - Method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
 
filterFiles(F[]) - Method in class org.springframework.integration.file.filters.ChainFileListFilter
 
filterFiles(F[]) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
filterFiles(F[]) - Method in interface org.springframework.integration.file.filters.FileListFilter
Filters out files and returns the files that are left in a list, or an empty list when a null is passed in.
filterFiles(File[]) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
filterFiles(F[]) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
filterFiles(F[]) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
filterFunction(Function<File, Boolean>) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
filterInRetry(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
The boolean flag to specify the order how RetryingMessageListenerAdapter and FilteringMessageListenerAdapter are wrapped to each other, if both of them are present.
filterMputFiles(File[]) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
FilterParser - Class in org.springframework.integration.config.xml
Parser for the <filter/> element.
FilterParser() - Constructor for class org.springframework.integration.config.xml.FilterParser
 
finalizeRaw() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
finalizeRaw() - Method in interface org.springframework.integration.file.remote.session.Session
Invoke after closing the InputStream from Session.readRaw(String).
finalizeRaw() - Method in class org.springframework.integration.ftp.session.FtpSession
 
finalizeRaw() - Method in class org.springframework.integration.sftp.session.SftpSession
 
find(Class<T>, Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
find(Class<T>, Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Find an Entity of given type with the given primary key type.
findAnnotatedMethod(Object, Class<? extends Annotation>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
 
findClosestMatch(Class<?>, Set<Class<?>>, boolean) - Static method in class org.springframework.integration.util.ClassUtils
 
findLastReleasedSequenceNumber(Object, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
findMessagePartAnnotation(Annotation[], boolean) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Find the one of Payload, Header or Headers annotation from the provided annotations array.
findProtocolHandler(WebSocketSession) - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
Resolves the SubProtocolHandler for the given session using its accepted sub-protocol.
firstId() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
firstLineAsHeader(String) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
Specify the header name for the first line to be carried as a header in the messages emitted for the remaining lines.
firstResult(int) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a first result in the query executed.
firstResultExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression that will be evaluated to get the first result in the query executed.
firstResultExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression that will be evaluated to get the first result in the query executed.
fixedDelay(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedDelay(long, TimeUnit) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedDelay(long, long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedDelay(long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedDelay(Duration) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedDelay(long) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedDelay(Duration, Duration) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedDelay(long, TimeUnit) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedDelay(long, long) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedDelay(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.Pollers
 
FixedMethodFilter - Class in org.springframework.integration.util
A MethodFilter implementation that will always return the same Method instance within a single-element list if it is present in the candidate list.
FixedMethodFilter(Method) - Constructor for class org.springframework.integration.util.FixedMethodFilter
 
fixedRate(long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedRate(long, TimeUnit) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedRate(long, long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedRate(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.PollerFactory
 
fixedRate(Duration) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedRate(long) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedRate(long, TimeUnit) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedRate(Duration, Duration) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedRate(long, long) - Static method in class org.springframework.integration.dsl.Pollers
 
fixedRate(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.Pollers
 
FixedSubscriberChannel - Class in org.springframework.integration.channel
Specialized SubscribableChannel for a single final subscriber set up during bean instantiation (unlike other SubscribableChannels where the MessageHandler is subscribed when the endpoint is started).
FixedSubscriberChannel() - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
 
FixedSubscriberChannel(MessageHandler) - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
 
fixedSubscriberChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate an FixedSubscriberChannel instance at the current IntegrationFlow chain position.
fixedSubscriberChannel(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate an FixedSubscriberChannel instance at the current IntegrationFlow chain position.
FixedSubscriberChannelBeanFactoryPostProcessor - Class in org.springframework.integration.config
Used to post process candidates for FixedSubscriberChannel MessageHandlers.
FixedSubscriberChannelPrototype - Class in org.springframework.integration.dsl.support
An "artificial" MessageChannel implementation which will be unwrapped to the FixedSubscriberChannel on the bean registration phase.
FixedSubscriberChannelPrototype() - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
FixedSubscriberChannelPrototype(String) - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
FLAGS - Static variable in class org.springframework.integration.mail.MailHeaders
 
flush() - Method in interface org.springframework.integration.jpa.core.JpaOperations
flush(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
If set to true the EntityManager.flush() will be called after persistence operation.
flush(Function<Message<P>, Boolean>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at runtime to determine whether or not to flush the producer after a send.
FLUSH - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
Set to Boolean.TRUE to flush after sending.
flush() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
flushableStore - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
flushAfterDelete(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
If set to true the EntityManager.flush() will be called after persistence operation.
flushAfterDelete(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
If set to true the EntityManager.flush() will be called after persistence operation.
flushExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine whether or not to flush the producer after a send.
flushExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure an Expression to determine whether or not to flush the producer after a send.
flushIfNeeded(FileWritingMessageHandler.FlushPredicate) - Method in class org.springframework.integration.file.FileWritingMessageHandler
When using FileExistsMode.APPEND_NO_FLUSH you can invoke this method to selectively flush and close open files.
flushIfNeeded(FileWritingMessageHandler.MessageFlushPredicate, Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
When using FileExistsMode.APPEND_NO_FLUSH you can invoke this method to selectively flush and close open files.
flushIfNeeded() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Flush the store if it's a Flushable and flushOnUpdate is true.
flushInterval(long) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the frequency to flush buffers when FileExistsMode.APPEND_NO_FLUSH is being used.
flushOnUpdate - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
flushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Specify a FileWritingMessageHandler.MessageFlushPredicate for flush task when the FileExistsMode.APPEND_NO_FLUSH is in use.
flushSize(int) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
If the provided value is greater than 0, then EntityManager.flush() will be called after persistence operations as well as within batch operations.
flushWhenIdle(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set the flush when idle flag to false if you wish the interval to apply to when the file was opened rather than when the file was last written.
flux() - Method in class org.springframework.integration.dsl.Channels
 
flux(String) - Method in class org.springframework.integration.dsl.Channels
 
flux() - Static method in class org.springframework.integration.dsl.MessageChannels
 
flux(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
FluxAggregatorMessageHandler - Class in org.springframework.integration.aggregator
The AbstractMessageProducingHandler implementation for aggregation logic based on Reactor's Flux.groupBy(java.util.function.Function<? super T, ? extends K>) and Flux.window(int) operators.
FluxAggregatorMessageHandler() - Constructor for class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Create an instance with a Flux.create(java.util.function.Consumer<? super reactor.core.publisher.FluxSink<T>>) and apply Flux.groupBy(java.util.function.Function<? super T, ? extends K>) and Flux.window(int) transformation into it.
FluxMessageChannel - Class in org.springframework.integration.channel
The AbstractMessageChannel implementation for the Reactive Streams Publisher based on the Project Reactor Flux.
FluxMessageChannel() - Constructor for class org.springframework.integration.channel.FluxMessageChannel
 
FluxMessageChannelSpec - Class in org.springframework.integration.dsl
 
FluxMessageChannelSpec() - Constructor for class org.springframework.integration.dsl.FluxMessageChannelSpec
 
fluxTransform(Function<? super Flux<Message<I>>, ? extends Publisher<O>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a FluxMessageChannel to start a reactive processing for upstream data, wrap it to a Flux, apply provided Function via Flux.transform(Function) and emit the result to one more FluxMessageChannel, subscribed in the downstream flow.
forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Force close the connection and null the field if it's a shared connection.
forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
forceComplete(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
forceReleaseAdvice(Advice...) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a list of Advice objects to be applied to the forceComplete() operation.
forLevel(Level) - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
The factory to produce Log4j2LevelAdjuster instances for arbitrary logging Level with the org.springframework.integration as default category.
from(String) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(String, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageProducerSupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSource<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessagingGatewaySupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageProducerSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessagingGatewaySpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(Class<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(Class<?>, Consumer<GatewayProxySpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
Start a flow from a proxy for the service interface.
from(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(String) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel name to the new IntegrationFlowBuilder chain.
from(String, boolean) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel name to the new IntegrationFlowBuilder chain.
from(MessageChannelSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel object to the IntegrationFlowBuilder chain using the fluent API from MessageChannelSpec.
from(MessageChannel) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageChannel object to the IntegrationFlowBuilder chain.
from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from the provided MessageSourceSpec.
from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from the provided MessageSourceSpec.
from(MessageSource<?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageSource object to the IntegrationFlowBuilder chain.
from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageSource object to the IntegrationFlowBuilder chain.
from(MessageProducerSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageProducerSupport object to the IntegrationFlowBuilder chain using the fluent API from the MessageProducerSpec.
from(MessageProducerSupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageProducerSupport object to the IntegrationFlowBuilder chain.
from(MessagingGatewaySpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessagingGatewaySupport object to the IntegrationFlowBuilder chain using the fluent API from the MessagingGatewaySpec.
from(MessagingGatewaySupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessagingGatewaySupport object to the IntegrationFlowBuilder chain.
from(Class<?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel to the new IntegrationFlowBuilder chain, which becomes as a requestChannel for the Messaging Gateway(s) built on the provided service interface.
from(Class<?>, Consumer<GatewayProxySpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel to the new IntegrationFlowBuilder chain, which becomes as a requestChannel for the Messaging Gateway(s) built on the provided service interface.
from(Publisher<? extends Message<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate a FluxMessageChannel to the IntegrationFlowBuilder chain and subscribe it to the provided Publisher.
from(Map<String, ?>) - Static method in class org.springframework.integration.expression.ExpressionEvalMap
 
from(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the From: address.
FROM - Static variable in class org.springframework.integration.mail.MailHeaders
 
FROM - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
fromExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine the From: address.
fromFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the From: address based on the message.
fromHeaders(MessageHeaders, HttpHeaders) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Map from the integration MessageHeaders to an HttpHeaders instance.
fromHeaders(MessageHeaders, Message) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
 
fromHeaders(MessageHeaders, MimeMessage) - Method in class org.springframework.integration.mail.support.DefaultMailHeaderMapper
 
fromHeaders(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
fromHeaders(MessageHeaders, StompHeaders) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
 
fromHeadersToReply(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
fromHeadersToReply(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given MessageHeaders to the specified reply target.
fromHeadersToRequest(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
fromHeadersToRequest(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given MessageHeaders to the specified request target.
fromJson() - Static method in class org.springframework.integration.dsl.Transformers
 
fromJson(Class<?>) - Static method in class org.springframework.integration.dsl.Transformers
 
fromJson(ResolvableType) - Static method in class org.springframework.integration.dsl.Transformers
Construct a JsonToObjectTransformer based on the provided ResolvableType.
fromJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
 
fromJson(Class<?>, JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
 
fromJson(ResolvableType, JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
Construct a JsonToObjectTransformer based on the provided ResolvableType and JsonObjectMapper.
fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, ResolvableType) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, J) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, JavaType) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
fromJson(JsonParser, Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
fromJson(Object, Class<T>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(Object, ResolvableType) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
Deserialize a JSON to an expected ResolvableType.
fromJson(Object, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(P, Type) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromMap(Class<?>) - Static method in class org.springframework.integration.dsl.Transformers
 
fromMap(String) - Static method in class org.springframework.integration.dsl.Transformers
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.codec.CodecMessageConverter
 
fromMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
 
fromMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
fromMessage(Message<?>) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
Raw byte[] from message, possibly with a length field up front.
fromMessage(Message<?>) - Method in class org.springframework.integration.mapping.ConvertingBytesMessageMapper
 
fromMessage(Message<?>) - Method in interface org.springframework.integration.mapping.OutboundMessageMapper
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
fromMessage(Message<T>) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
 
fromMessage(Message<?>) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
 
fromMessage(Message<?>) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MessageBuilder
Create a builder for a new Message instance pre-populated with all of the headers copied from the provided message.
fromMessage(Message<T>) - Method in interface org.springframework.integration.support.MessageBuilderFactory
 
fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MutableMessageBuilder
Create a builder for a new Message instance pre-populated with all of the headers copied from the provided message.
fromMessage(Message<T>) - Method in class org.springframework.integration.support.MutableMessageBuilderFactory
 
fromSoapHeaders(MessageContext, AbstractIntegrationMessageBuilder<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
fromStream() - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the StreamTransformer.
fromStream(String) - Static method in class org.springframework.integration.dsl.Transformers
Create an instance with the charset to convert the stream to a String; if null a byte[] will be produced instead.
fromSupplier(Supplier<T>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
fromSupplier(Supplier<T>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
fromSupplier(Supplier<T>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Provides Supplier as source of messages to the integration flow which will be triggered by the application context's default poller (which must be declared).
fromSupplier(Supplier<T>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Provides Supplier as source of messages to the integration flow.
fromSyslog(Message<?>) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
fromSyslog(Message<?>) - Method in interface org.springframework.integration.syslog.MessageConverter
 
fromSyslog(Message<?>) - Method in class org.springframework.integration.syslog.RFC5424MessageConverter
 
Ftp - Class in org.springframework.integration.ftp.dsl
The factory for FTP components.
FtpFileInfo - Class in org.springframework.integration.ftp.session
A FileInfo implementation for FTP/FTPS.
FtpFileInfo(FTPFile) - Constructor for class org.springframework.integration.ftp.session.FtpFileInfo
 
FtpInboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
Parser for the FTP 'inbound-channel-adapter' element.
FtpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
FtpInboundChannelAdapterSpec - Class in org.springframework.integration.ftp.dsl
FtpInboundChannelAdapterSpec(SessionFactory<FTPFile>, Comparator<File>) - Constructor for class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
 
FtpInboundFileSynchronizer - Class in org.springframework.integration.ftp.inbound
An implementation of AbstractInboundFileSynchronizer for FTP.
FtpInboundFileSynchronizer(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
Create a synchronizer with the SessionFactory used to acquire Session instances.
FtpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.ftp.inbound
A MessageSource implementation for FTP.
FtpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
 
FtpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<FTPFile>, Comparator<File>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
 
FtpMessageHandler - Class in org.springframework.integration.ftp.outbound
The FTP specific FileTransferringMessageHandler extension.
FtpMessageHandler(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
 
FtpMessageHandler(FtpRemoteFileTemplate) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
 
FtpMessageHandler(RemoteFileTemplate<FTPFile>, FileExistsMode) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
FtpMessageHandler(FtpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
Constructor which sets the FtpRemoteFileTemplate and FileExistsMode.
FtpMessageHandlerSpec - Class in org.springframework.integration.ftp.dsl
FtpMessageHandlerSpec(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
 
FtpMessageHandlerSpec(RemoteFileTemplate<FTPFile>) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
Deprecated.
FtpMessageHandlerSpec(RemoteFileTemplate<FTPFile>, FileExistsMode) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
Deprecated.
FtpMessageHandlerSpec(FtpRemoteFileTemplate) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
 
FtpMessageHandlerSpec(FtpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
 
FtpNamespaceHandler - Class in org.springframework.integration.ftp.config
Provides namespace support for using FTP
FtpNamespaceHandler() - Constructor for class org.springframework.integration.ftp.config.FtpNamespaceHandler
 
FtpOutboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
Parser for FTP Outbound Channel Adapters.
FtpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
 
FtpOutboundGateway - Class in org.springframework.integration.ftp.gateway
Outbound Gateway for performing remote file operations via FTP/FTPS.
FtpOutboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance using the provided session factory and callback for performing operations on the session.
FtpOutboundGateway(RemoteFileTemplate<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance with the supplied remote file template and callback for performing operations on the session.
FtpOutboundGateway(SessionFactory<FTPFile>, String, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
FtpOutboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
FtpOutboundGateway(SessionFactory<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance with the supplied session factory and command ('ls', 'nlst', 'put' or 'mput').
FtpOutboundGateway(RemoteFileTemplate<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Construct an instance with the supplied remote file template and command ('ls', 'nlst', 'put' or 'mput').
FtpOutboundGatewayParser - Class in org.springframework.integration.ftp.config
 
FtpOutboundGatewayParser() - Constructor for class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
FtpOutboundGatewaySpec - Class in org.springframework.integration.ftp.dsl
FtpOutboundGatewaySpec(FtpOutboundGateway) - Constructor for class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
 
FtpPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.ftp.filters
Persistent file list filter using the server's file timestamp to detect if we've already 'seen' this file.
FtpPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
 
FtpRegexPatternFileListFilter - Class in org.springframework.integration.ftp.filters
Implementation of AbstractRegexPatternFileListFilter for FTP.
FtpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
 
FtpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
 
FtpRemoteFileTemplate - Class in org.springframework.integration.ftp.session
FTP version of RemoteFileTemplate providing type-safe access to the underlying FTPClient object.
FtpRemoteFileTemplate(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
 
FtpRemoteFileTemplate.ExistsMode - Enum in org.springframework.integration.ftp.session
FtpRequestEvent - Class in org.springframework.integration.ftp.server
Base class for all events having an FtpRequest.
FtpRequestEvent(FtpSession, FtpRequest) - Constructor for class org.springframework.integration.ftp.server.FtpRequestEvent
 
FtpSession - Class in org.springframework.integration.ftp.session
Implementation of Session for FTP.
FtpSession(FTPClient) - Constructor for class org.springframework.integration.ftp.session.FtpSession
 
FtpSimplePatternFileListFilter - Class in org.springframework.integration.ftp.filters
Implementation of AbstractSimplePatternFileListFilter for FTP.
FtpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
 
FtpStreamingInboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
 
FtpStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
FtpStreamingInboundChannelAdapterSpec - Class in org.springframework.integration.ftp.dsl
FtpStreamingInboundChannelAdapterSpec(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Constructor for class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
 
FtpStreamingMessageSource - Class in org.springframework.integration.ftp.inbound
Message source for streaming FTP remote file contents.
FtpStreamingMessageSource(RemoteFileTemplate<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
Construct an instance with the supplied template.
FtpStreamingMessageSource(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
Construct an instance with the supplied template and comparator.
FtpSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.ftp.filters
FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
 
FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
 
FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>, Function<String, String>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
 
FtpSystemMarkerFilePresentFileListFilter(Map<FileListFilter<FTPFile>, Function<String, String>>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
 
FUNCTION_APPLY_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The Function.apply(Object) method object.
FunctionExpression<S> - Class in org.springframework.integration.expression
An Expression that simply invokes Function.apply(Object) on its provided Function.
FunctionExpression(Function<S, ?>) - Constructor for class org.springframework.integration.expression.FunctionExpression
 
FunctionIterator<T,V> - Class in org.springframework.integration.util
An Iterator implementation to convert each item from the target FunctionIterator.iterator to a new object applying the FunctionIterator.function on FunctionIterator.next().
FunctionIterator(Iterable<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
Construct an instance with the provided iterable and function.
FunctionIterator(AutoCloseable, Iterable<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
Construct an instance with the provided root object, iterable and function.
FunctionIterator(Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
Construct an instance with the provided iterator and function.
FunctionIterator(AutoCloseable, Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
Construct an instance with the provided root object, iterator and function.
FUTURE_TOKEN - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
Set to a token to correlate a send Future.
futuresChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which send futures are sent.
futuresChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which send futures are sent.

G

Gateway - Annotation Type in org.springframework.integration.annotation
Indicates that an interface method is capable of mapping its parameters to a message or message payload.
gateway(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(String, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
gateway(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(MessageChannel, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
gateway(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow.
gateway(IntegrationFlow, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow with options from GatewayEndpointSpec.
GatewayEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec implementation for a mid-flow GatewayMessageHandler.
GatewayEndpointSpec(MessageChannel) - Constructor for class org.springframework.integration.dsl.GatewayEndpointSpec
 
GatewayEndpointSpec(String) - Constructor for class org.springframework.integration.dsl.GatewayEndpointSpec
 
GatewayHeader - Annotation Type in org.springframework.integration.annotation
Provides the message header value or expression.
gatewayInterceptors - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
gatewayMarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
 
gatewayMarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
GatewayMessageHandler - Class in org.springframework.integration.gateway
The AbstractReplyProducingMessageHandler implementation for mid-flow Gateway.
GatewayMessageHandler() - Constructor for class org.springframework.integration.gateway.GatewayMessageHandler
 
gatewayMethodMetadata - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
GatewayMethodMetadata - Class in org.springframework.integration.gateway
Represents the metadata associated with a Gateway method.
GatewayMethodMetadata() - Constructor for class org.springframework.integration.gateway.GatewayMethodMetadata
 
GatewayParser - Class in org.springframework.integration.config.xml
Parser for the <gateway/> element.
GatewayParser() - Constructor for class org.springframework.integration.config.xml.GatewayParser
 
gatewayProxyFactoryBean - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
GatewayProxyFactoryBean - Class in org.springframework.integration.gateway
Generates a proxy for the provided service interface to enable interaction with messaging components without application code being aware of them allowing for POJO-style interaction.
GatewayProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
Create a Factory whose service interface type can be configured by setter injection.
GatewayProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
GatewayProxySpec - Class in org.springframework.integration.dsl
A builder for the GatewayProxyFactoryBean options when MessagingGateway on the service interface cannot be declared.
GatewayProxySpec(Class<?>) - Constructor for class org.springframework.integration.dsl.GatewayProxySpec
 
gatewayRequestChannel - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
gatewayUnmarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
 
gatewayUnmarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
gatherChannel(MessageChannel) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a MessageChannel (optional) which is used internally in the ScatterGatherHandler for gathering (aggregate) results for scattered requests.
gatherTimeout(long) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a timeout (in milliseconds) for the PollableChannel.receive(long) operation to wait for gathering results to output.
gaugeBuilder(String, Object, ToDoubleFunction<Object>) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Create a gauge builder for a gauge with the provided parameters.
gaugeBuilder(String, Object, ToDoubleFunction<Object>) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
GaugeFacade - Interface in org.springframework.integration.support.management.metrics
 
GemfireCqInboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
 
GemfireCqInboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireCqInboundChannelAdapterParser
 
GemfireInboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
 
GemfireInboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireInboundChannelAdapterParser
 
GemfireIntegrationNamespaceHandler - Class in org.springframework.integration.gemfire.config.xml
 
GemfireIntegrationNamespaceHandler() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireIntegrationNamespaceHandler
 
GemfireLockRegistry - Class in org.springframework.integration.gemfire.util
Implementation of LockRegistry providing a distributed lock using Gemfire.
GemfireLockRegistry(Cache) - Constructor for class org.springframework.integration.gemfire.util.GemfireLockRegistry
 
GemfireLockRegistry(Region<?, ?>) - Constructor for class org.springframework.integration.gemfire.util.GemfireLockRegistry
 
GemfireMessageStore - Class in org.springframework.integration.gemfire.store
Gemfire implementation of the key/value style MessageStore and MessageGroupStore
GemfireMessageStore(Region<Object, Object>) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
Provides the region to be used for the message store.
GemfireMessageStore(Region<Object, Object>, String) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
Construct a GemfireMessageStore instance based on the provided
GemfireMetadataStore - Class in org.springframework.integration.gemfire.metadata
Gemfire implementation of ListenableMetadataStore.
GemfireMetadataStore(Cache) - Constructor for class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
GemfireMetadataStore(Region<String, String>) - Constructor for class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
GemfireOutboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
 
GemfireOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireOutboundChannelAdapterParser
 
GeneralSftpException - Exception in org.springframework.integration.sftp.support
Simple runtime exception to wrap an SftpException.
GeneralSftpException(String, Throwable) - Constructor for exception org.springframework.integration.sftp.support.GeneralSftpException
 
generateAlias(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
generateBeanName(String, Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
generateCorrelationData(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateExchangeName(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateFileName(Message<?>) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.file.FileNameGenerator
 
generateHandlerBeanName(String, Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
generateHandlerBeanName(String, Method) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
generateId() - Static method in class org.springframework.integration.context.IntegrationObjectSupport
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.JdkIdGenerator
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
generateRoutingKey(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateScriptName(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
generateScriptVariables(Message<?>) - Method in class org.springframework.integration.scripting.DefaultScriptVariableGenerator
 
generateScriptVariables(Message<?>) - Method in interface org.springframework.integration.scripting.ScriptVariableGenerator
 
generateSearchTerm(Flags, Folder) - Method in interface org.springframework.integration.mail.SearchTermStrategy
Will generate an instance of the SearchTerm
GenericEndpointSpec<H extends MessageHandler> - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec for a MessageHandler implementations.
GenericEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.GenericEndpointSpec
 
GenericHandler<P> - Interface in org.springframework.integration.handler
A functional interface to specify MessageHandler logic with Java 8 Lambda expression:
 .<Integer>handle((p, h) -> p / 2)
 
GenericMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the GenericMessage.
GenericMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
 
GenericSelector<S> - Interface in org.springframework.integration.core
Generic (lambda) strategy interface for selector.
GenericTransformer<S,T> - Interface in org.springframework.integration.transformer
Generic (lambda) strategy interface for transformer.
get() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
get() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowExtension
 
get(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
Gets the value(Expression) for the provided key from ExpressionEvalMap.original and returns the result of evaluation using ExpressionEvalMap.evaluationCallback.
get(Message<?>, Session<F>, String, String, String, F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Copy a remote file to the configured local directory.
get(String, InputStreamCallback) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Retrieve a remote file as an InputStream.
get(Message<?>, InputStreamCallback) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Retrieve a remote file as an InputStream, based on information in a message.
get(Message<?>, InputStreamCallback) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
get(String, InputStreamCallback) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
get(Message<?>, Session<FTPFile>, String, String, String, FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
get(String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
get(int) - Method in class org.springframework.integration.history.MessageHistory
 
get(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
get(int) - Method in class org.springframework.integration.json.JsonPropertyAccessor.ArrayNodeAsList
 
get(String) - Method in interface org.springframework.integration.metadata.MetadataStore
Reads a value for the given key from this MetadataStore.
get(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
get(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
get(String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Get the value for the provided key performing findOne MongoDB operation.
get(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
Retrieve the persisted value for the provided key.
get() - Method in class org.springframework.integration.support.MapBuilder
 
get() - Method in class org.springframework.integration.support.PropertiesBuilder
 
get(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getAckInfo() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
getAcknowledgment(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getAcknowledgmentCallback() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Return the acknowledgment callback, if present.
getAcknowledgmentCallback(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getAckPort() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getActiveCount() - Method in interface org.springframework.integration.util.Pool
Returns the number of allocated items that are currently checked out of the pool.
getActiveCount() - Method in class org.springframework.integration.util.SimplePool
 
getActiveHandlerCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Deprecated.
getActiveHandlerCountLong() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Deprecated.
getAdmin() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getAdvice() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getAdviceChain() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getAdvicesAndAdvisorsForBean(Class<?>, String, TargetSource) - Method in class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
getAdvisedHandler() - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
Utility method, intended for use in message handler advice classes to get information about the advised object.
getAge() - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
getAggregatedExceptions() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
Obtain a list aggregated target exceptions.
getAllConfigAttributes() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getAllocatedCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getAllocatedCount() - Method in interface org.springframework.integration.util.Pool
Returns the current count of allocated items (in use and idle).
getAllocatedCount() - Method in class org.springframework.integration.util.SimplePool
 
getAllowCredentials() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getAllowedHeaders() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getAmqpMessage() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getAmqpTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getAnnotatedMethods(String) - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getAnnotationChain(Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getAnnotations() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getApplicationContext() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getApplicationContext() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getApplicationContext() - Method in class org.springframework.integration.graph.IntegrationGraphServer
 
getApplicationContext() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getApplicationContextId() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Returns the ApplicationContext.getId() if the ApplicationContext is available.
getApplicationContextId() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
getArgs() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getAssignedPartitions() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Return the currently assigned partitions.
getAsyncClientInstance(String, String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getAsyncClientInstance(String, String) - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve an async client instance.
getAsyncExecutor() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getAttributeAccessor(Message<?>, Message<?>) - Static method in class org.springframework.integration.support.ErrorMessageUtils
Return a AttributeAccessor for the provided arguments.
getAttributes(Object) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getAttributes() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
Will return an immutable Map of current attributes.
getAttrs() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
getBackendPort() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the port a backend socket is bound or null if this proxy has not been started yet.
getBackendSocketType() - Method in enum org.springframework.integration.zeromq.ZeroMqProxy.Type
 
getBacklog() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
The number of sockets in the server connection backlog.
getBasePackages(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
getBatchingStrategy() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SelectorChainParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
 
getBeanClass(Element) - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
getBeanClass(Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
getBeanClass(Element) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
getBeanClass(Element) - Method in class org.springframework.integration.webflux.config.WebFluxInboundEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
 
getBeanClass(Element) - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
 
getBeanClass(Element) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
getBeanClass(Element) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
getBeanClassLoader() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getBeanClassLoader() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getBeanClassLoader() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
Deprecated.
 
getBeanClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.PresenceInboundChannelAdapterParser
 
getBeanDefinition(String, ConfigurableListableBeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return a BeanDefinition with the given name, obtained from the given BeanFactory or one of its parents.
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
getBeanDescription() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanFactory() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getBeanFactory() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getBeanFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanFactory() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getBeanFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getBeanFactory() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getBeanFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getBeanName() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getBeanName() - Method in class org.springframework.integration.channel.NullChannel
 
getBeanName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getBeanName() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
getBeanName() - Method in interface org.springframework.integration.mqtt.core.MqttComponent
Return this component's bean name.
getBeanName() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getBeanName() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
getBeanName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getBeansOfType(Class<T>) - Method in class org.springframework.integration.graph.IntegrationGraphServer
Get beans for the provided type from the application context.
getBoundPort() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return the port this internal server is bound or empty Mono.
getBoundPort() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Return the port a socket is bound or 0 if this message producer has not been started yet or the socket is connected - not bound.
getBuffer() - Method in class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundChannelAdapterParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.webflux.config.WebFluxOutboundChannelAdapterParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.webflux.config.WebFluxOutboundGatewayParser
 
getBytes() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getc() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getCacheLevel() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getCaptureAddress() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the address an inproc capture socket is bound or null if this proxy has not been started yet or ZeroMqProxy.captureAddress is false.
getCause() - Method in class org.springframework.integration.events.IntegrationEvent
 
getChannel() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getChannel() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
Return the channel.
getChannel() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getChannel() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getChannel(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
getChannel() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getChannelCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Subclasses must implement this method to return the channel keys.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter
Selects the most appropriate channel name matching channel identifiers which are the fully qualified class names encountered while traversing the payload type hierarchy.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.xml.router.XPathRouter
 
getChannelMappings() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Returns an unmodifiable version of the channel mappings.
getChannelMappings() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
 
getChannelMetrics(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Deprecated.
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getChannelNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
getChannelResolver() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getChannelResolver() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getChannelResolver(BeanFactory) - Static method in class org.springframework.integration.support.channel.ChannelResolverUtils
Obtain a DestinationResolver registered with the "integrationChannelResolver" bean name.
getCharset() - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
getClassLoader() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getClassLoader() - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
getClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getClientId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getClientId() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getClientId() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getClientId() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getClientInstance() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
getClientInstance() - Method in interface org.springframework.integration.file.remote.session.Session
Get the underlying client library's client instance for this session.
getClientInstance() - Method in class org.springframework.integration.ftp.session.FtpSession
 
getClientInstance(String, String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getClientInstance(String, String) - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve a client instance.
getClientInstance() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getClientInstance() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Incremented each time the client is connected.
getClientInstance() - Method in class org.springframework.integration.sftp.session.SftpSession
 
getClientRSocketRequester(Object) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return connected RSocketRequester mapped by key or null.
getClientRSocketRequester(Object) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Obtain a connected RSocketRequester mapped by provided key or null.
getClientRSocketRequesters() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return connected RSocketRequesters mapped by keys.
getClientRSocketRequesters() - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Get connected RSocketRequesters mapped by the keys from the connect messages.
getClientVersion() - Method in class org.springframework.integration.sftp.server.SessionOpenedEvent
 
getCloseableResource() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
If the payload was created by a Closeable that needs to remain open until the payload is consumed, the resource will be added to this header.
getCloseableResource(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getCode() - Method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
Get the numerical representation of the JDBC Type enum.
getCommand() - Method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
 
getCommand() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
getCommitTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getComparator() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getComponentName() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentName() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Will return the name of this component identified by IntegrationObjectSupport.componentName field.
getComponentName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getComponentName() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getComponentName() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
getComponentName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentNamePatternsString() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.AggregatorSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
 
getComponentsToRegister() - Method in interface org.springframework.integration.dsl.ComponentsRegistration
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.EndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.GatewayProxySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.PollerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.RouterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.WireTapSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
 
getComponentsToRegister() - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
 
getComponentType() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
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
 
getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getComponentType() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentType() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getComponentType() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this method to provide component type information.
getComponentType() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.MessageProcessorMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
getComponentType() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
getComponentType() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getComponentType() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
getComponentType() - Method in class org.springframework.integration.filter.MessageFilter
 
getComponentType() - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
 
getComponentType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getComponentType() - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
getComponentType() - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.graph.IntegrationNode
 
getComponentType() - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
getComponentType() - Method in class org.springframework.integration.handler.BridgeHandler
 
getComponentType() - Method in class org.springframework.integration.handler.DelayHandler
 
getComponentType() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.LoggingHandler
 
getComponentType() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getComponentType() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getComponentType() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
getComponentType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
getComponentType() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
getComponentType() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
getComponentType() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
getComponentType() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
 
getComponentType() - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
getComponentType() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.json.ObjectToJsonTransformer
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getComponentType() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.mail.MailSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
 
getComponentType() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getComponentType() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
 
getComponentType() - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
getComponentType() - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
getComponentType() - Method in class org.springframework.integration.rmi.RmiOutboundGateway
Deprecated.
 
getComponentType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getComponentType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getComponentType() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
getComponentType() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
 
getComponentType() - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
 
getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getComponentType() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.stream.ByteStreamWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
getComponentType() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentType() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ContentEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderFilter
 
getComponentType() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
getComponentType() - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
getComponentType() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
getComponentType() - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.xml.router.XPathRouter
 
getComponentType() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.XPathTransformer
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
getComponentType() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
getComponentType() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
getComponentType() - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
getComponentType() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
 
getConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getConfigAttributesForReceive() - Method in interface org.springframework.integration.security.channel.ChannelAccessPolicy
 
getConfigAttributesForReceive() - Method in class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
 
getConfigAttributesForSend() - Method in interface org.springframework.integration.security.channel.ChannelAccessPolicy
 
getConfigAttributesForSend() - Method in class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
 
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
 
getConnectHeaders() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getConnection() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Obtains a connection - if AbstractConnectionFactory.setSingleUse(boolean) was called with true, a new connection is returned; otherwise a single connection is reused for all requests while the connection remains open.
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Not supported because the factory manages multiple connections and this method cannot discriminate.
getConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ConnectionFactory
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getConnection() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getConnectionFactory() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getConnectionId() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedCorrelationEvent
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getConnectionInfo() - Method in interface org.springframework.integration.mqtt.core.MqttComponent
Return information about the connection.
getConnectionInfo() - Method in interface org.springframework.integration.mqtt.core.MqttPahoComponent
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
getConnectionOptions() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getConnectionOptions() - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve the connection options.
getConnections() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
getConnections() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getConnections() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getConnectionTest() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Get a Predicate that will be invoked to test a new connection; return true to accept the connection, false the reject.
getConnectTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
getConsumer() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getConsumerMonitor() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getConsumerMonitor() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getConsumerProperties() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Get a reference to the configured consumer properties; allows further customization of the properties before the source is started.
getConsumerStopAction() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
Get the consumer stop action.
getConsumerStopAction() - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Get the consumer stop action.
getConsumes() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getContentDescriptor() - Method in class org.springframework.integration.graph.Graph
 
getContentType() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getContentType(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getContext() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the Context associated with this event.
getContext() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getContext() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
The context of the initiator.
getControlAddress() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the address an inproc control socket is bound or null if this proxy has not been started yet.
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getConversionService() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getConversionService(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
 
getConverter() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getConverter() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getConverter() - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
Get the configured Converter.
getConverter() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
getCorrelationData() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
 
getCorrelationDataGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getCorrelationId() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getCorrelationId() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.MessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getCorrelationKey(Message<?>) - Method in interface org.springframework.integration.aggregator.CorrelationStrategy
Find the correlation key for the given message.
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
getCorrelationStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getCorsConfiguration(Object, HttpServletRequest) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
getCount() - Method in class org.springframework.integration.graph.TimerStats
 
getCountAllMessagesInGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getCountAllMessagesInGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve a count of all messages currently persisted for a channel.
getCreatedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query to add a single message to the database.
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getCrossOrigin() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getCurrent() - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
Return the current RotationPolicy.KeyDirectory.
getCurrent() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getCurrentComponent() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getCurrentMessageChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getData() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getDataLen() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
getDataMimeType() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getDefaultDeliveryMode() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getDefaultErrorChannel() - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
Return the default error channel for this error handler.
getDefaultErrorChannel() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the default error channel if the error handler is explicitly provided and it is a MessagePublishingErrorHandler.
getDefaultOutputChannel() - Method in class org.springframework.integration.router.AbstractMessageRouter
Get the default output channel.
getDefaultOutputChannel() - Method in interface org.springframework.integration.router.MessageRouter
Get the default output channel.
getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.scheduling.PollerMetadata
Return the default PollerMetadata bean if available.
getDefaultReplyChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDelayedMessageCount() - Method in class org.springframework.integration.handler.DelayHandler
 
getDelayedMessageCount() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
 
getDelayedReads() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getDelegate() - Method in class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
Get access to the delegate ReactiveMessageHandler.
getDeleteMessageGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getDeleteMessageGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query to delete all messages that belong to a specific channel.
getDeleteMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getDeleteMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query to delete a single message from the database.
getDeliveryAttempt() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
When a message-driven endpoint supports retry implicitly, this header is incremented for each delivery attempt.
getDeliveryAttempt(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getDeliveryMode() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getDeliveryTag() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
Return the delivery tag for the last failed message.
getDerivedInput() - Method in exception org.springframework.integration.support.PartialSuccessException
getDerivedInput(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getDerivedInput() to avoid casting
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getDeserializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getDeserializerStateKey() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getDestination() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getDestinationAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getDestinations() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
getDirectory() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
getDiscardChannel() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscardChannel() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getDiscardChannel() - Method in class org.springframework.integration.filter.MessageFilter
 
getDiscardChannel() - Method in interface org.springframework.integration.handler.DiscardingMessageHandler
Return the discard channel.
getDiscardChannel() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getDiscardChannelName() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscards() - Method in class org.springframework.integration.graph.DiscardingMessageHandlerNode
 
getDispatcher() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.DirectChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.ExecutorChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getDocumentBuilder() - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
getDstPath() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
 
getDuration() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Return the duration.
getDynamicChannelNames() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
 
getDynamicChannelNames() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide a collection of channel names to which we have routed messages where the channel was not explicitly mapped.
getEnclosingClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getEndpointsRunningStatus(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return the running status of each endpoint in the role.
getEntityName(EntityManager, Class<?>) - Static method in class org.springframework.integration.jpa.support.JpaUtils
 
getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getErrorChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Return the error channel (if provided) to which error messages will be routed.
getErrorChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getErrorChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return the error channel (if provided) to which error messages will be routed.
getErrorChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getErrorHandler(BeanFactory) - Static method in class org.springframework.integration.channel.ChannelUtils
Obtain an ErrorHandler registered with the "integrationMessagePublishingErrorHandler" bean name.
getErrorHandler() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
getErrorMessageStrategy() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableCompositeMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableDiscardingMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableEndpointNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableMessageHandlerNode
 
getErrors() - Method in interface org.springframework.integration.graph.ErrorCapableNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableRoutingNode
 
getEvaluationContext() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getEvaluationContext() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getEvaluationContext(boolean) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
Emits a WARN log if the beanFactory field is null, unless the argument is false.
getEvaluationResult() - Method in exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
 
getExceptions() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
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
 
getExpirationDate() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getExpirationDate(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getExpired() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getExpireGroupScheduledFutures() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getExposedHeaders() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getExpression() - Method in interface org.springframework.integration.context.ExpressionCapable
Return the primary SpEL expression if this component is expression-based.
getExpression() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getExpression() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getExpression(String, Locale) - Method in interface org.springframework.integration.expression.ExpressionSource
 
getExpression(String, Locale) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Resolves the given key in the retrieved bundle files to an Expression.
getExpression() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getExpression() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
getExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getExpressionFor(String) - Static method in class org.springframework.integration.context.IntegrationProperties
Build the bean property definition expression to resolve the value from Integration properties within the bean building phase.
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.FunctionExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.SupplierExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.ValueExpression
 
getExpressionString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
getExtractReplyPayload() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getFactory() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getFactoryLocator() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Return this factory's locator.
getFailures() - Method in class org.springframework.integration.graph.ReceiveCounters
 
getFailures() - Method in class org.springframework.integration.graph.SendTimers
 
getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
 
getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getFile(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFile() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
getFileInfo() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getFileInfo() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getFileInfo() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Return the name of the file represented by this F.
getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
Subclasses must implement this method to extract the file's name.
getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
Subclasses must implement this method to extract the file's name.
getFilename(File) - Method in class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
getFilename(File) - Method in class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
getFilename(File) - Method in class org.springframework.integration.file.filters.SimplePatternFileListFilter
 
getFilename() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getFilename(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getFilename(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getFilename(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getFilename(AbstractFileInfo<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
getFilename() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
 
getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getFilename(AbstractFileInfo<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
getFilename() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getFileNames() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilePath() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getFiles(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilter() - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
getFirstDate(String, String) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getFirstParameterType() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getFolderOpenMode() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getForString(String) - Static method in enum org.springframework.integration.file.support.FileExistsMode
For a given non-null and not-empty input string, this method returns the corresponding FileExistsMode.
getFrameType() - Method in enum org.springframework.integration.rsocket.RSocketInteractionModel
 
getFrom() - Method in class org.springframework.integration.graph.LinkNode
 
getFrontendPort() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the port a frontend socket is bound or 0 if this proxy has not been started yet.
getFrontendSocketType() - Method in enum org.springframework.integration.zeromq.ZeroMqProxy.Type
 
getFullChannelName() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Returns the fully qualified channel name including the application context id, if available.
getFunctionName() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getFunctions() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getFuture() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
getFuturesChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getGatewayClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getGatewayClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
Deprecated.
 
getGatewayClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
getGateways() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Return the Map of Method to MessagingGatewaySupport generated by this factory bean.
getGetResponse() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getGlobalMethodMetadata() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getGraph() - Method in class org.springframework.integration.graph.IntegrationGraphServer
Return the cached graph.
getGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
 
getGroupCreatedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getGroupId() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getGroupId() - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 
getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getGroupId() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getGroupId() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getGroupId() - Method in interface org.springframework.integration.store.MessageGroup
 
getGroupId() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getGroupMetadata(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Obtain the group metadata without fetching any messages; must supply all other group properties; may include the id of the first message.
getGroupMetadata(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getGroupPrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message group keys to distinguish between different store instances in the same target key-value data base.
getGroupTimeoutExpression() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getHandler() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getHandler() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the consumer's handler.
getHandler() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getHandler() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getHandler(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
 
getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
 
getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.PresenceOutboundChannelAdapterParser
 
getHandlerCount() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
getHandlerCount() - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
Return the current handler count.
getHandlerCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlerExecutionChain(Object, HttpServletRequest) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in interface org.springframework.integration.dispatcher.LoadBalancingStrategy
 
getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
Returns an iterator that starts at a new point in the collection every time the first part of the list that is skipped will be used at the end of the iteration, so it guarantees all handlers are returned once on subsequent next() invocations.
getHandlerMetrics(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Deprecated.
getHandlerNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Returns an unmodifiable Set of this dispatcher's handlers.
getHandlers() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode
 
getHandlers() - Method in interface org.springframework.integration.handler.CompositeMessageHandler
Return an unmodifiable list of handlers.
getHandlers() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getHeader(Map<?, ?>, String) - Static method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
SpEL Function to retrieve a required header.
getHeader(String, Class<T>) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.MessageBuilder
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getHeaderExpressions() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getHeaderExpressions() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getHeaderMapper() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getHeaderMapper() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getHeaderMapper() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getHeaderMapper() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getHeaderMapper() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
getHeaderPatterns() - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
 
getHeaders() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getHeaders() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getHeaders() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getHeaders() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.MessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessage
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getHeadersFunction() - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
getHeaderTypes() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
getHost() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getHost() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getHost() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getHostAddress() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getHostName() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getHostName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getHostName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getHostPort() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
getHostPort() - Method in interface org.springframework.integration.file.remote.session.Session
Return the host:port pair this session is connected to.
getHostPort() - Method in class org.springframework.integration.ftp.session.FtpSession
 
getHostPort() - Method in class org.springframework.integration.sftp.session.SftpSession
 
getHttpHeader(HttpHeaders, String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getIChannelInterceptorList() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Exposes the interceptor list instance for subclasses.
getId() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow id.
getId() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
getId() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getId() - Method in interface org.springframework.integration.leader.Candidate
Gets the identifier.
getId(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getIdentifier() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getIdleConsumerLimit() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getIdleCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getIdleCount() - Method in interface org.springframework.integration.util.Pool
Returns the number of items that have been allocated but are not currently in use.
getIdleCount() - Method in class org.springframework.integration.util.SimplePool
 
getIdleTaskExecutionLimit() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getInboundHeaderMapper() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getIndex() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getInetAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getInitialDuration() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Get the initial duration.
getInput() - Method in class org.springframework.integration.graph.MessageHandlerNode
 
getInputChannel() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow input channel.
getInputChannel() - Method in interface org.springframework.integration.dsl.IntegrationFlow
Return the first MessageChannel component which is essential a flow input channel.
getInputChannel() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getInputChannel() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getInputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getInputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the input channel.
getInputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getInputChannel() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
getInputChannelAttributeName() - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.file.config.FileOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.ip.config.TcpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jms.config.JmsOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.mongodb.config.MongoDbOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.redis.config.RedisOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
 
getInputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getInputMessage() - Method in class org.springframework.integration.message.AdviceMessage
 
getInputStream() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getInt() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getIntegrationComponents() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getIntegrationComponents() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getIntegrationFlow() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow.
getIntegrationPatternCategory() - Method in class org.springframework.integration.graph.IntegrationNode
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.NullChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getIntegrationPatternType() - Method in interface org.springframework.integration.channel.ReactiveStreamsSubscribableChannel
 
getIntegrationPatternType() - Method in interface org.springframework.integration.core.MessageSource
 
getIntegrationPatternType() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.filter.MessageFilter
 
getIntegrationPatternType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.graph.IntegrationNode
 
getIntegrationPatternType() - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.BridgeHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.DelayHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getIntegrationPatternType() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
getIntegrationPatternType() - Method in interface org.springframework.integration.IntegrationPattern
Return a pattern type this component implements.
getIntegrationPatternType() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getIntegrationPatternType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getIntegrationPatternType() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ContentEnricher
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.HeaderFilter
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getIntegrationProperties(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getIntegrationProperties() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getIntegrationProperty(String, Class<T>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getInteractionModels() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
 
getInteractionModels() - Method in interface org.springframework.integration.rsocket.IntegrationRSocketEndpoint
Obtain RSocketInteractionModels this ReactiveMessageHandler is going to be mapped onto.
getInterceptor() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactory
Called for each new connection; a new interceptor must be returned on each call.
getInterceptorFactories() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return a read-only list of the configured interceptors.
getInterfaceNames() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getItem() - Method in interface org.springframework.integration.util.Pool
Obtains an item from the pool.
getItem() - Method in class org.springframework.integration.util.SimplePool
Obtains an item from the pool; waits up to waitTime milliseconds (default infinity).
getIterator() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getJavaMailProperties() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getJdbcOperations() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
To be used to get a reference to JdbcOperations in case this class is subclassed
getJpaExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
Create a new BeanDefinitionBuilder for the class JpaExecutor.
getJpaParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
Create a ManagedList of BeanDefinitions containing parsed JPA Parameters.
getKafkaTemplate() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getKey() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
getKeyDirectories() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getLastMessage() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
 
getLastModified() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getLastModified() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastModified() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastModified() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLastModifiedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getLastRead() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getLastReleasedMessageSequenceNumber() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLastReleasedSequence() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getLastSend() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getLevel() - Method in class org.springframework.integration.handler.LoggingHandler
 
getLifecycleMonitor() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getLineCount() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getLinks() - Method in class org.springframework.integration.graph.Graph
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getListener() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getListener() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
getListener() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
getLocalAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocalPort() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocalSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocker() - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
getLockRegistry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getManagedName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedName() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedName() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getManagedName() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
getManagedResource(Class<?>) - Method in class org.springframework.integration.monitor.IntegrationJmxAttributeSource
 
getManagedType() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedType() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getManagedType() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
getMapper() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getMapper() - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.AbstractRouterParser
Returns the name of the attribute that provides a key for the channel mappings.
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
getMappingMongoConverter() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMark() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getMarkedSegment() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getMax() - Method in class org.springframework.integration.graph.TimerStats
 
getMaxAge() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getMaxConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getMaxFetchSize() - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
 
getMaxFetchSize() - Method in interface org.springframework.integration.support.management.MessageSourceManagement
Return the max fetch size.
getMaxMessageSize() - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
The maximum supported message size for this serializer.
getMaxMessagesPerPoll() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getMaxMessagesPerTask() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getMean() - Method in class org.springframework.integration.graph.TimerStats
 
getMemberClassNames() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getMessage() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
getMessage() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
getMessage() - Method in class org.springframework.integration.event.core.MessagingEvent
 
getMessage() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
Return the text message emitted from the underlying tailing producer (Apache Commons or one of OS natives).
getMessage() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessage() - Method in exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
getMessage(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessage() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessage() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
getMessage() - Method in class org.springframework.integration.mqtt.event.MqttSubscribedEvent
 
getMessage() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getMessage() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessage() - Method in class org.springframework.integration.store.MessageHolder
 
getMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessage() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getMessage() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
getMessage() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getMessageBuilderFactory() - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
getMessageBuilderFactory() - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
getMessageBuilderFactory() - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
getMessageBuilderFactory(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Returns the context-wide `messageBuilderFactory` bean from the beanFactory, or a DefaultMessageBuilderFactory if not found or the beanFactory is null.
getMessageBuilderFactory() - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getMessageConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getMessageConverter() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getMessageConverters() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
getMessageCount() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getMessageCount() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageCount() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageCount() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageCount() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageCount() - Method in interface org.springframework.integration.store.MessageStore
Optional attribute giving the number of messages in the store.
getMessageCount() - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageCountForAllMessageGroups() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of messages in the store over all groups.
getMessageCountForRegionQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getMessageCountForRegionQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query that retrieve a count of all messages for a region.
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Not fully used.
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
Not fully used.
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Will create a new instance of SimpleMessageGroup if necessary.
getMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Return all Messages currently in the MessageStore that were stored using BasicMessageGroupStore.addMessageToGroup(Object, Message) with this group id.
getMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Method not implemented.
getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageGroupCount() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of message groups.
getMessageGroupFactory() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageGroupStore() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the store.
getMessageId() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getMessageId() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getMessageId() - Method in class org.springframework.integration.store.MessageMetadata
 
getMessageIds() - Method in class org.springframework.integration.store.MessageGroupMetadata
Obtain a LinkedList copy of the MessageGroupMetadata.messageIds stored in the group.
getMessageMetadata(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageMetadata() - Method in class org.springframework.integration.store.MessageHolder
 
getMessageMetadata(UUID) - Method in interface org.springframework.integration.store.MessageStore
Return a MessageMetadata for the Message by provided id.
getMessageMetadata(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessagePrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message keys to distinguish between different store instances in the same target key-value data base.
getMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
 
getMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query that retrieves a message for the provided message id, channel and region.
getMessages() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessages() - Method in interface org.springframework.integration.store.MessageGroup
Returns all available Messages from the group at the time of invocation
getMessages() - Method in class org.springframework.integration.store.MessageGroupQueue
 
getMessages() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getMessages() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessagesForGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Retrieve messages for the provided group id.
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageSource() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Return this endpoint's source.
getMessageSourceClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getMessageSourceClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getMessageSourceClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getMessageSourceClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getMessageSourceClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getMessageSourceClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getMessageStore() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMessageStoreNotEmpty() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the not empty condition.
getMessageStoreNotFull() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the not full condition.
getMessagingTemplate() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getMessagingTemplate() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow.
getMessagingTemplate() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getMessagingTemplate() - Method in class org.springframework.integration.router.AbstractMessageRouter
Provides MessagingTemplate access for subclasses
getMetadataMimeType() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getMetadataStore(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
Get the meter.
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
getMeterRegistry() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
getMethod() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getMethod() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getMethodInvocation() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getMetrics() - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Obtain the metrics from the rate limiter.
getMetricsCaptor() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMetricsCaptor() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getMinimumTimeoutForEmptyGroups() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMissingFileDelay() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getModified() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getModified(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getModified(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getModified(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getModified(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
getModified() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getModified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getModified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
getModified() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getMongoTemplate() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMultiFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getMultipartContentType(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
Once we depend upon Spring 3.1 as a minimum, this code can be changed to: this.multipartServletRequest.getMultipartContentType(String paramOrFileName)
getNackReason() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
 
getName() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
getName() - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
getName() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
 
getName() - Method in class org.springframework.integration.graph.IntegrationNode
 
getName() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getName() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getName() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getName() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
getName() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getNewChannels() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
getNewDocumentBuilder() - Method in class org.springframework.integration.xml.result.DomResultFactory
 
getNextId() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
Perform MongoDB INC operation for the document, which contains the MessageDocument sequence, and return the new incremented value for the new MessageDocument.
getNextPath(Message<?>, Object) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
getNextPath(Message<?>, Object) - Method in interface org.springframework.integration.routingslip.RoutingSlipRouteStrategy
Get the next path for this routing slip.
getNodeId() - Method in class org.springframework.integration.graph.IntegrationNode
 
getNodes() - Method in class org.springframework.integration.graph.Graph
 
getNotPropagatedHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Get the header patterns this handler doesn't propagate.
getNotPropagatedHeaders() - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Get the header names this handler doesn't propagate.
getObject() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getObject() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObject() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getObject() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getObject() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getObject() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getObjectMapper() - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
getObjectType() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
getObjectType() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
getObjectType() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
getObjectType() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
getObjectType() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
getObjectType() - Method in class org.springframework.integration.sftp.session.JschProxyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getObjectType() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getObjectType() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getOffendingJPAQl() - Method in exception org.springframework.integration.jpa.core.JpaOperationFailedException
 
getOffset() - Method in class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
getOffsets() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getOffsets() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getOne() - Method in interface org.springframework.integration.store.MessageGroup
 
getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getOneMessageFromGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Return the one Message from MessageGroup.
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getOOBInline() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getOpenConnectionIds() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Returns a list of (currently) open TcpConnection connection ids; allows, for example, broadcast operations to all open connections.
getOpenConnectionIds() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getOption() - Method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
 
getOrder() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getOrder() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
getOrder() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getOrder() - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
 
getOrigin() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getOriginal() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
getOriginalFilename() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getOutboundGatewayJpaExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
Create a new BeanDefinitionBuilder for the class JpaExecutor that is specific for JPA Outbound Gateways.
getOutput() - Method in class org.springframework.integration.graph.EndpointNode
 
getOutputChannel() - Method in interface org.springframework.integration.core.MessageProducer
Return the the output channel.
getOutputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getOutputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the output channel (may be null).
getOutputChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getOutputChannel() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
getOutputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getOutputProcessor() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Return a configured MessageGroupProcessor.
getOverrides() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getOverrides() - Method in class org.springframework.integration.channel.NullChannel
 
getOverrides() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getOverrides() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getOverrides() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getOverrides() - Method in interface org.springframework.integration.support.management.IntegrationManagement
Return the overrides.
getParameterMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getParams() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getPartialResults() - Method in exception org.springframework.integration.support.PartialSuccessException
getPartialResults(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getPartialResults() to avoid casting
getPath() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Get an array of the path patterns this endpoint is mapped onto.
getPath() - Method in interface org.springframework.integration.rsocket.IntegrationRSocketEndpoint
Obtain path patterns this ReactiveMessageHandler is going to be mapped onto.
getPath() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
getPath() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
 
getPath(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getPathPatterns() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getPatternCategory() - Method in enum org.springframework.integration.IntegrationPatternType
 
getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getPatterns() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getPatternTypes() - Method in enum org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
 
getPayload() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getPayload() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Uses the deserializer to obtain the message payload from the connection's input stream.
getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getPayload() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getPayload() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.MessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.MutableMessage
 
getPayload() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getPayload() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getPayloadExpression() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getPayloadExpression() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getPayloadType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getPayloadType() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
getPermissions() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getPermissions() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getPermissions() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getPhase() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
getPhase() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getPhase() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
getPhase() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getPhase() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getPhase() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
getPhase() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getPhase() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
getPhase() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
getPhase() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
getPhase() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
getPhase() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getPhase() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
getPhase() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getPhase() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
getPhase() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
getPhase() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getPhase() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
getPhase() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getPhase() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getPhase() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
getPhase() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getPollFromGroupExcludeIdsQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message for a channel excluding messages that match the provided message ids.
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message for a channel.
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getPollingFlux() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getPollTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getPoolSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getPoolSize() - Method in interface org.springframework.integration.util.Pool
Returns the current size (limit) of the pool.
getPoolSize() - Method in class org.springframework.integration.util.SimplePool
Returns the current size of the pool; may be greater than the target pool size if it was recently reduced and too many items were in use to allow the new size to be set.
getPort() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getPort() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionServerListeningEvent
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getPort() - Method in interface org.springframework.integration.ip.tcp.connection.TcpServerConnectionFactory
Return the port this server is listening on.
getPort() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.udp.UdpServerListeningEvent
 
getPort() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
getPort() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
getPostProcessors() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Subclasses can override this to return a more specific type before handler creation.
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.FilterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.RouterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.TransformerFactoryBean
 
getPriority() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getPriority() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getPriority() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getPriority(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message by priority for a channel excluding messages that match the provided message ids.
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message by priority for a channel.
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getProcedureParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getProduces() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getProjectionExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getProperties() - Method in class org.springframework.integration.graph.IntegrationNode
 
getPropertiesConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getPropertyAccessors() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getPropertyAccessors() - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Return the registered accessors.
getPropertyValue(Object, String) - Static method in class org.springframework.integration.test.util.TestUtils
Obtain a value for the property from the provide object.
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.integration.test.util.TestUtils
Obtain a value for the property from the provide object and try to cast it to the provided type.
getPushbackBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
 
getQos() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getQos() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getQuery(JdbcChannelMessageStore.Query, Supplier<String>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Replace patterns in the input to produce a valid SQL query.
getQuery(JdbcMessageStore.Query) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
Replace patterns in the input to produce a valid SQL query.
getQueryString(String, String) - Static method in class org.springframework.integration.jpa.support.JpaUtils
Returns the query string for the given class name.
getQueuedMessageCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getQueueSize() - Method in class org.springframework.integration.channel.QueueChannel
 
getQueueSize() - Method in interface org.springframework.integration.channel.QueueChannelOperations
Obtain the current number of queued Messages in this channel.
getQueueSize() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
Returns the size of the Queue specified by RedisQueueInboundGateway.boundListOperations.
getQueueSize() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
Returns the size of the Queue specified by RedisQueueMessageDrivenEndpoint.boundListOperations.
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
 
getRateLimiter() - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Get the RateLimiter which is configured for this advice.
getRawHeaders() - Method in class org.springframework.integration.support.MutableMessageHeaders
 
getReadablePropertyNames() - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
Provide access to the property names of the wrapped bean.
getReadDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getReaperDelay() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
getRebalanceListener() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getReceiptId() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getReceiveCounters() - Method in class org.springframework.integration.graph.MessageSourceNode
 
getReceiveCounters() - Method in class org.springframework.integration.graph.PollableChannelNode
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getReceiveTimeout() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getReceiveTimeout() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getReceiveTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getRecipients() - Method in class org.springframework.integration.router.RecipientListRouter
 
getRecipients() - Method in interface org.springframework.integration.router.RecipientListRouterManagement
 
getRecord() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getRecord() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getRecord() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
getRecoveryInterval() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getRecoveryInterval() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getRedisTemplate() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getRegistrationById(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Obtain an IntegrationFlowContext.IntegrationFlowRegistration for the IntegrationFlow associated with the provided flowId.
getRegistrationById(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Obtain an IntegrationFlowRegistration for the IntegrationFlow associated with the provided flowId.
getRegistrations() - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
 
getRegistrations() - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
getRegistry() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Provide the state of the mapping of integration flow names to their IntegrationFlowContext.IntegrationFlowRegistration instances.
getRegistry() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Provide the state of the mapping of integration flow names to their IntegrationFlowRegistration instances.
getReleaseStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.PriorityChannel
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getRemainingCapacity() - Method in interface org.springframework.integration.channel.QueueChannelOperations
Obtain the remaining capacity of this channel.
getRemoteDirectory() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
getRemoteDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getRemoteFileMetadata(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Obtain a metadata for remote file associated with the provided local file.
getRemoteFilename(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getRemoteFileSeparator() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getRemoteFileTemplate() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
getRemoteFileTemplate() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getRemoteHandle() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
getRemoteSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getRemoveBatchSize() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getReply(ResponseEntity<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
getReply() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getReplyChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return this gateway's reply channel if any.
getReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getReplyCode() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getReplyText() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequest() - Method in class org.springframework.integration.ftp.server.FtpRequestEvent
 
getRequest() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getRequestChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return this gateway's request channel.
getRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequestDate() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
getRequester() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Return the RSocketRequester this connector is built on.
getRequester() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getRequestMapping() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getRequestMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getRequestPayloadType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequiredConversionService() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getRequiresReply() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getResource() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
getResourceHolder() - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
getResourceKey() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the key under which the resource will be made available as an attribute on the IntegrationResourceHolder.
getResourceKey() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceKey() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return a resource (MessageSource etc) to bind when using transaction synchronization.
getResourceToBind() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getResponseValidator() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getResultFactory() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
getResultFactoryName() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
getResultListForClass(Class<?>, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForClass(Class<?>, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
getResultListForNamedQuery(String, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForNamedQuery(String, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
getResultListForNativeQuery(String, Class<?>, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForNativeQuery(String, Class<?>, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
getResultListForQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForQuery(String, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the provided query to return a list of results
getResultListForQuery(String, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the provided query to return a list of results.
getResultType() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getReturnChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getReturningResultsetBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getReuseAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getRole() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
getRole() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getRole() - Method in interface org.springframework.integration.leader.Candidate
Gets the role.
getRole() - Method in interface org.springframework.integration.leader.Context
Get the role for the Candidate.
getRole() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the role of the leader.
getRoles() - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return a collection of the roles currently managed by this controller.
getRoot() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getRoutes() - Method in class org.springframework.integration.graph.RoutingMessageHandlerNode
 
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
 
getRSocketRequester() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Deprecated.
getRSocketStrategies() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getScanner() - Method in class org.springframework.integration.file.FileReadingMessageSource
The FileReadingMessageSource.scanner property accessor to allow to modify its options (filter, locker etc.) at runtime using the FileReadingMessageSource bean.
getScriptAsString() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
getScriptEngine() - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
getScriptExecutor(String) - Static method in class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
 
getScriptSource(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
getScriptSource(Message<?>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
 
getScriptSource(Message<?>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Subclasses must implement this method to create a script source, optionally using the message to locate or create the script.
getScriptSource(Message<?>) - Method in class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
 
getScriptVariableGenerator() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getSecureObjectClass() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
getSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Return the list of senders.
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Return the list of senders.
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSendFailureChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getSendSuccessChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getSendTimeout() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
getSendTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getSendTimers() - Method in class org.springframework.integration.graph.MessageChannelNode
 
getSendTimers() - Method in class org.springframework.integration.graph.MessageHandlerNode
 
getSequence() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getSequenceDetails() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceNumber(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getSequenceNumber() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceSize(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSerializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getServerChannel() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getServerConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getServerConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getServerSocket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getServerSocketAddress() - Method in interface org.springframework.integration.ip.tcp.connection.TcpServerConnectionFactory
Return the SocketAddress that the underlying ServerSocket is bound to.
getServerSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
 
getServerSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
 
getServerSocketFactory() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketFactorySupport
Supplies the ServerSocketFactory to be used to create new ServerSockets.
getSession() - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Obtain a raw Session object.
getSession() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getSession() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Get a session from the pool (or block if none available).
getSession() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
 
getSession(Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
 
getSession() - Method in interface org.springframework.integration.file.remote.session.SessionFactory
 
getSession() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
 
getSession() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
getSession() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
 
getSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
getSession(String) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
getSession(String) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getSessionAcknowledgeMode() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getSessionAcknowledgeModeName() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getSessionFactory() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getSessionFactory(Object) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
 
getSessionFactory(Object) - Method in interface org.springframework.integration.file.remote.session.SessionFactoryLocator
Return a SessionFactory for the key.
getSessions() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getSingleResultForQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getSingleResultForQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the provided query to return a single element
getSize() - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
getSize() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getSize() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getSize() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getSize() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getSizeOfIdCache() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Returns the size of the Message Id Cache, which caches Message Ids for those messages that are currently being processed.
getSocket() - Method in class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
 
getSocket() - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
getSocket() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
getSocket() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
 
getSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
 
getSocketFactory() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketFactorySupport
Supplies the SocketFactory to be used to create new Sockets.
getSocketInfo() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Provides getters for Socket properties.
getSocketInfo() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSocketInfo() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSoTimeout() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getSoTimeout() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSource(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceAsType() - Method in class org.springframework.integration.events.IntegrationEvent
Get the source as a specific type; the receiving variable must be declared with the correct type.
getSourceCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceData() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Get the source data header, if present.
getSourceData(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getSourceMetrics(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Deprecated.
getSourceNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSpecificTargetClasses() - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
getSpelExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getSqlParameterDefinitionBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getSrcPath() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
 
getSSLChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
getSSLContext() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
 
getSSLContext() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSSLContextSupport
Gets an SSLContext.
getSslHandshakeTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSslSession() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
getStatusCodeExpression() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getStompCommand() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getStoredProcedureName() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
 
getStoredProcedureNameExpressionAsString() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
 
getStoredProcExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
Create a new BeanDefinitionBuilder for the class StoredProcExecutor.
getStoreLock() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the store lock.
getSubProtocols() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
getSubProtocols() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getSubProtocols() - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
Return the List of sub-protocols from provided SubProtocolHandler.
getSubscriberCount() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
getSubscriberCount() - Method in interface org.springframework.integration.support.management.SubscribableChannelManagement
The number of message handlers currently subscribed to this channel.
getSuccesses() - Method in class org.springframework.integration.graph.ReceiveCounters
 
getSuccesses() - Method in class org.springframework.integration.graph.SendTimers
 
getSuperClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
getSupportedProtocols() - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
getSynchronizer() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Return the underlying synchronizer.
getTarget() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ArrayNodeAsList
 
getTarget() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
getTarget() - Method in interface org.springframework.integration.json.JsonPropertyAccessor.WrappedJsonNode
Return the wrapped JsonNode
getTaskExecutor() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getTaskExecutor() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getTaskExecutor() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getTaskExecutor() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Creates a taskExecutor (if one was not provided).
getTaskExecutor() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getTaskExecutor() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getTaskScheduler() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getTcpSocketFactorySupport() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
getTcpSocketFactorySupport() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getTcpSocketSupport() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getTemplate() - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 
getTemplateClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getTemporaryFileSuffix() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getTextFromAttributeOrNestedElement(Element, String, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Get a text value from a named attribute if it exists, otherwise check for a nested element of the same name.
getTheConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
getTheConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
Returns the underlying connection (or next interceptor)
getTheSocket() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
getTheSocket() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getThisAs() - Method in interface org.springframework.integration.support.management.IntegrationManagement
Return this IntegrationManagement as its concrete type.
getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getTimestamp(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getTimestamp() - Method in interface org.springframework.integration.store.MessageGroup
 
getTimestamp() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getTimestamp() - Method in class org.springframework.integration.store.MessageMetadata
 
getTimestamp() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getTimestamp(RFC5424SyslogParser.Reader) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser
Default implementation returns the date as a String (if present).
getTimeToLive() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getTo() - Method in class org.springframework.integration.graph.LinkNode
 
getTopic() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getTopic() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
getTopic() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getTopicPartition() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getTopicPartition() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getTransactionSynchronizationFactory() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.StreamTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.file.config.FileToByteArrayTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.file.config.FileToStringTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.mail.config.MailToStringTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.xml.config.MarshallingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.xml.config.UnmarshallingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
getTransformerClassName() - Method in class org.springframework.integration.xml.config.XPathTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.xml.config.XsltPayloadTransformerParser
 
getTransientHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Return the transient header names.
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getType() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
 
getType() - Method in class org.springframework.integration.graph.LinkNode
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getType() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
getTypeConverter() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getUrl() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getUrl() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getUrl() - Method in enum org.springframework.integration.xml.selector.XmlValidatingMessageSelector.SchemaType
 
getUserData() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
getUserFlag() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getUUID(Object) - Static method in class org.springframework.integration.util.UUIDConverter
Convenient utility to convert an object to a UUID.
getValidator() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getValue() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Object, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Object, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue() - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
getValue() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
 
getValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
getValue(String) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSource
Return the parameter value for the requested named parameter.
getValueByPosition(int) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
getValueByPosition(int) - Method in interface org.springframework.integration.jpa.support.parametersource.PositionSupportingParameterSource
 
getValueType() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getWebServiceTemplate() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
getXmppConnection() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
getXmppConnection() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
getXPathExpresion() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
GLOBAL_CHANNEL_INTERCEPTOR_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
GlobalChannelInterceptor - Annotation Type in org.springframework.integration.config
ChannelInterceptor components with this annotation will be applied as global channel interceptors using the provided patterns to match channel names.
GlobalChannelInterceptorInitializer - Class in org.springframework.integration.config
GlobalChannelInterceptorInitializer() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorInitializer
 
GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
Parser for 'channel-interceptor' elements.
GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
GlobalChannelInterceptorProcessor - Class in org.springframework.integration.config
This class applies global interceptors (<channel-interceptor> or @GlobalChannelInterceptor) to message channels beans.
GlobalChannelInterceptorProcessor() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
GlobalChannelInterceptorWrapper - Class in org.springframework.integration.channel.interceptor
 
GlobalChannelInterceptorWrapper(ChannelInterceptor) - Constructor for class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
GlobalWireTapParser - Class in org.springframework.integration.config.xml
Parser for the top level 'wire-tap' element
GlobalWireTapParser() - Constructor for class org.springframework.integration.config.xml.GlobalWireTapParser
 
Graph - Class in org.springframework.integration.graph
This object can be exposed, for example, as a JSON object over HTTP.
Graph(Map<String, Object>, Collection<IntegrationNode>, Collection<LinkNode>) - Constructor for class org.springframework.integration.graph.Graph
 
GRAPH_CONTROLLER_BEAN_NAME - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the bean name for the default IntegrationGraphController.
GRAPH_CONTROLLER_DEFAULT_PATH - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the default request mapping path for the IntegrationGraphController.
GRAPH_CONTROLLER_PATH_PROPERTY - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the environment property for the IntegrationGraphController request mapping path.
GroovyAwareScriptExecutingProcessorFactory - Class in org.springframework.integration.groovy.config
The factory to create GroovyScriptExecutingMessageProcessor instances if provided language == "groovy", otherwise delegates to the super class.
GroovyAwareScriptExecutingProcessorFactory() - Constructor for class org.springframework.integration.groovy.config.GroovyAwareScriptExecutingProcessorFactory
 
GroovyCommandMessageProcessor - Class in org.springframework.integration.groovy
 
GroovyCommandMessageProcessor() - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
GroovyCommandMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Creates a GroovyCommandMessageProcessor that will use the provided ScriptVariableGenerator.
GroovyCommandMessageProcessor(Binding) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Creates a GroovyCommandMessageProcessor that will use the DefaultScriptVariableGenerator and provided Binding.
GroovyCommandMessageProcessor(Binding, ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Creates a GroovyCommandMessageProcessor that will use the provided ScriptVariableGenerator and Binding.
GroovyControlBusFactoryBean - Class in org.springframework.integration.groovy.config
FactoryBean for creating MessageHandler instances to handle a message as a Groovy Script.
GroovyControlBusFactoryBean() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
GroovyControlBusParser - Class in org.springframework.integration.groovy.config
Parser for the <groovy:control-bus/> element.
GroovyControlBusParser() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusParser
 
GroovyIntegrationConfigurationInitializer - Class in org.springframework.integration.groovy.config
The Groovy Module Integration infrastructure beanFactory initializer.
GroovyIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
 
GroovyNamespaceHandler - Class in org.springframework.integration.groovy.config
 
GroovyNamespaceHandler() - Constructor for class org.springframework.integration.groovy.config.GroovyNamespaceHandler
 
GroovyScriptExecutingMessageProcessor - Class in org.springframework.integration.groovy
The MessageProcessor implementation to evaluate Groovy scripts.
GroovyScriptExecutingMessageProcessor(ScriptSource) - Constructor for class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Create a processor for the given ScriptSource that will use a DefaultScriptVariableGenerator.
GroovyScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Create a processor for the given ScriptSource that will use the provided ScriptVariableGenerator.
GroovyScriptParser - Class in org.springframework.integration.groovy.config
Parser for the <groovy:script/> element.
GroovyScriptParser() - Constructor for class org.springframework.integration.groovy.config.GroovyScriptParser
 
GROUP_ID - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
groupId - Variable in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 
groupId(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
Set the group id to use on the consumer side.
groupId(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the group id for this container.
groupIdQuery(Object) - Static method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
groupTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a group timeout expression that evaluates to this constant value.
groupTimeout(Function<MessageGroup, Long>) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a function that will be invoked to resolve the group timeout, based on the message group.
groupTimeoutExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 

H

H2ChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
H2ChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
handle(MessageHandlerSpec<?, H>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Namespace Factory:
 .handle(Amqp.outboundAdapter(this.amqpTemplate).routingKeyExpression("headers.routingKey"))
 
handle(MessageHandler) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the provided MessageHandler implementation.
handle(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(String, String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the discovered method for provided service at runtime.
handle(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(Object, String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(Class<P>, GenericHandler<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(Class<P>, GenericHandler<P>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MessageProcessor from the provided MessageProcessorSpec.
handle(MessageProcessorSpec<?>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MessageProcessor from the provided MessageProcessorSpec.
handle(MessageHandlerSpec<?, H>, Consumer<GenericEndpointSpec<H>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Namespace Factory: In addition accept options for the integration endpoint using GenericEndpointSpec.
handle(H, Consumer<GenericEndpointSpec<H>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler for the provided MessageHandler implementation.
handle(GenericHandler<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(GenericHandler<P>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(String) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
handle(Exception) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
handle(P, MessageHeaders) - Method in interface org.springframework.integration.handler.GenericHandler
 
handle(ServerWebExchange) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
 
handleConfirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
handleError(Throwable) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Handle a message.
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReactiveMessageHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
 
handleMessage(Message<?>) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
 
handleMessage(Message<?>) - Method in class org.springframework.integration.test.support.AbstractResponseValidator
handle the message
handleMessageAdvice(MethodInterceptor...) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Configure a list of MethodInterceptor objects to be applied, in nested order, to the endpoint's handler.
HandleMessageAdvice - Interface in org.springframework.integration.handler.advice
The marker MethodInterceptor interface extension to distinguish advices for some reason.
HandleMessageAdviceAdapter - Class in org.springframework.integration.handler.advice
A HandleMessageAdvice implementation with a plain delegation to the provided MethodInterceptor.
HandleMessageAdviceAdapter(MethodInterceptor) - Constructor for class org.springframework.integration.handler.advice.HandleMessageAdviceAdapter
 
handleMessageFromClient(WebSocketSession, WebSocketMessage<?>, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractReactiveMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.LoggingHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
Writes the message payload to the underlying socket, using the specified message format.
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
Executes the update, passing the message into the SqlParameterSourceFactory.
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.jdbc.StoredProcMessageHandler
Executes the Stored procedure, delegates to executeStoredProcedure(...).
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.mail.MailSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Will extract the payload from the Message and store it in the collection identified by the key (which may be determined by an expression).
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.stream.ByteStreamWritingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.test.mock.MockMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
 
handleMessageToClient(WebSocketSession, Message<?>) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
handleNext(Consumer<Message<?>>) - Method in class org.springframework.integration.test.mock.MockMessageHandler
Add the Consumer to the stack to handle the next incoming message.
handleNextAndReply(Function<Message<?>, ?>) - Method in class org.springframework.integration.test.mock.MockMessageHandler
Add the Function to the stack to handle the next incoming message and produce reply for it.
handleNotification(Notification, Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Notification handling method implementation.
handler - Variable in class org.springframework.integration.dsl.EndpointSpec
 
HANDLER_ALIAS_SUFFIX - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
HANDLER_HANDLE_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The org.springframework.integration.handler.GenericHandler#handle(Object, Map) method object.
HANDLER_MAPPING_BEAN_NAME - Static variable in class org.springframework.integration.http.config.HttpContextUtils
The name for the infrastructure IntegrationRequestMappingHandlerMapping bean.
HANDLER_MAPPING_BEAN_NAME - Static variable in class org.springframework.integration.webflux.support.WebFluxContextUtils
The name for the infrastructure WebFluxIntegrationRequestMappingHandlerMapping bean.
handlerClass() - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
handlerClass() - Method in class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
 
handlerClass() - Method in class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
 
handleReadException(Exception) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
handleRequest(HttpServletRequest, HttpServletResponse) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Handles the HTTP request by generating a Message and sending it to the request channel.
handleRequest(HttpServletRequest, HttpServletResponse) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
Handles the HTTP request by generating a Message and sending it to the request channel.
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Subclasses must implement this method to handle the request Message.
handleRequestMessage(Message<?>) - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.BridgeHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.DelayHandler
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
Deprecated.
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
handleResult(ServerWebExchange, HandlerResult) - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
 
harvestClosedConnections() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Cleans up this.connections by removing any closed connections.
hasAdviceChain() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
hasAllEntries(Map<T, V>) - Static method in class org.springframework.integration.test.matcher.MapContentMatchers
 
hasAllHeaders(Map<String, ?>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasCorrelationId(V) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasExecutorInterceptors() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
hasExecutorInterceptors() - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
hasExecutorInterceptors() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
hasExecutorInterceptors() - Method in interface org.springframework.integration.channel.ExecutorChannelInterceptorAware
 
hasExecutorInterceptors() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
hasExecutorInterceptors() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
hasExpirationDate(Date) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasExpirationDate(Matcher<Long>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hashCode() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
hashCode() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
hashCode() - Method in exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
hashCode() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
hashCode() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
hashCode() - Method in class org.springframework.integration.message.AdviceMessage
 
hashCode() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
hashCode() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
hashCode() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
hashCode() - Method in class org.springframework.integration.support.MutableMessage
 
hashCode() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
hashCode() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
hasHeader(String, V) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasHeader(String, Matcher<V>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasHeaderKey(String) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasMessageId(V) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasNext() - Method in class org.springframework.integration.util.FunctionIterator
 
hasPayload(P) - Static method in class org.springframework.integration.test.matcher.PayloadMatcher
 
hasPayload(Matcher<P>) - Static method in class org.springframework.integration.test.matcher.PayloadMatcher
 
hasRealSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
hasReplies - Variable in class org.springframework.integration.test.mock.MockMessageHandler
 
hasSequenceNumber(Integer) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasSequenceNumber(Matcher<Integer>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasSequenceSize(Integer) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasSequenceSize(Matcher<Integer>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasTimestamp(Date) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasTimestamp(Matcher<Long>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
 
hasValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
hasValue(String) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSource
Determine whether there is a value for the specified named parameter.
hasValue(Object) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
 
HeadDirectoryScanner - Class in org.springframework.integration.file
A custom scanner that only returns the first maxNumberOfFiles elements from a directory listing.
HeadDirectoryScanner(int) - Constructor for class org.springframework.integration.file.HeadDirectoryScanner
 
header(String, V) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the value if it is not already present.
header(String, V, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
header(String, HeaderValueMessageProcessor<V>) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header value using an explicit HeaderValueMessageProcessor.
header(String, Object) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Provides custom message header.
header(String, Function<MethodArgsHolder, ?>) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Provides custom message header.
header(String, Expression) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Provides custom message header.
header(String, V) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification.
header(String, V, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification.
header(String, HeaderValueMessageProcessor<V>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by calling the HeaderValueMessageProcessor.
HEADER_NAME - Static variable in class org.springframework.integration.history.MessageHistory
 
HEADER_SIZE_INT - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Default length-header field, allows for data up to 2**31-1 bytes.
HEADER_SIZE_UNSIGNED_BYTE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
A single unsigned byte, for data up to 255 bytes.
HEADER_SIZE_UNSIGNED_SHORT - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
An unsigned short, for data up to 2**16 bytes.
HeaderAttributeCorrelationStrategy - Class in org.springframework.integration.aggregator
Default implementation of CorrelationStrategy.
HeaderAttributeCorrelationStrategy(String) - Constructor for class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
HeaderChannelRegistry - Interface in org.springframework.integration.support.channel
Implementations convert a channel to a name, retaining a reference to the channel keyed by the name.
headerChannelsToString() - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications to automatically convert header channels (reply, error channels) to Strings and store them in a header channel registry.
headerChannelsToString(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications to automatically convert header channels (reply, error channels) to Strings and store them in a header channel registry.
headerEnricher - Variable in class org.springframework.integration.dsl.HeaderEnricherSpec
 
HeaderEnricher - Class in org.springframework.integration.transformer
A Transformer that adds statically configured header values to a Message.
HeaderEnricher() - Constructor for class org.springframework.integration.transformer.HeaderEnricher
 
HeaderEnricher(Map<String, ? extends HeaderValueMessageProcessor<?>>) - Constructor for class org.springframework.integration.transformer.HeaderEnricher
Create a HeaderEnricher with the given map of headers.
HeaderEnricherParserSupport - Class in org.springframework.integration.config.xml
Base support class for 'header-enricher' parsers.
HeaderEnricherParserSupport() - Constructor for class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
HeaderEnricherSpec - Class in org.springframework.integration.dsl
HeaderEnricherSpec() - Constructor for class org.springframework.integration.dsl.HeaderEnricherSpec
 
headerExpression(String, String) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the expression evaluation if the header is not already present.
headerExpression(String, String, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
headerExpression(String, String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is a String representation of a SpEL Expression.
headerExpression(String, String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is a String representation of a SpEL Expression.
headerExpression(String, String) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify SpEL expression for provided header to populate.
headerExpression(String, Expression) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify SpEL expression for provided header to populate.
headerExpressions - Variable in class org.springframework.integration.dsl.EnricherSpec
 
headerExpressions - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
headerExpressions(MapBuilder<?, String, String>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(MapBuilder<?, String, String>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Consumer<StringStringMapBuilder>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications via the consumer callback, which receives a StringStringMapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Consumer<StringStringMapBuilder>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications via the consumer callback, which receives a StringStringMapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Map<String, String>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Map<String, String>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions - Variable in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
headerExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a Map of SpEL expressions to evaluate in order to generate the Message headers.
headerFilter(String...) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Provide the HeaderFilter to the current StandardIntegrationFlow.
headerFilter(String, boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Provide the HeaderFilter to the current StandardIntegrationFlow.
headerFilter(HeaderFilter, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided MessageTransformingHandler for the provided HeaderFilter.
HeaderFilter - Class in org.springframework.integration.transformer
Transformer that removes Message headers.
HeaderFilter(String...) - Constructor for class org.springframework.integration.transformer.HeaderFilter
 
HeaderFilterParser - Class in org.springframework.integration.config.xml
Parser for the 'header-filter' element.
HeaderFilterParser() - Constructor for class org.springframework.integration.config.xml.HeaderFilterParser
 
headerFunction(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the function return value if the header is not already present.
headerFunction(String, Function<Message<P>, Object>, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
headerFunction(String, Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by invoking the Function callback.
headerFunction(String, Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by invoking the Function callback.
headerFunction(String, Function<HttpEntity<P>, ?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a Function for provided header to populate.
headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
 
headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
Configure the adapter's AmqpHeaderMapper; defaults to DefaultAmqpHeaderMapper.
headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
 
headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
Configure the gateway's AmqpHeaderMapper; defaults to DefaultAmqpHeaderMapper.
headerMapper - Variable in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
 
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(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
headerMapper - Variable in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
headerMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
Configure a JmsHeaderMapper to map from JMS headers and properties to Spring Integration headers.
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
 
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
 
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
headerMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Specify a header mapper to map spring messaging headers to Kafka headers.
headerMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Set the header mapper; if a header mapper is not provided, the message payload is a MimeMessage, when provided, the headers are mapped and the payload is the MimeMessage content.
headerMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Set the header mapper; if a header mapper is not provided, the message payload is a MimeMessage, when provided, the headers are mapped and the payload is the MimeMessage content.
HeaderMapper<T> - Interface in org.springframework.integration.mapping
Generic strategy interface for mapping MessageHeaders to and from other types of objects.
headerMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
Configure the header mapper.
headerMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Configure the header mapper.
HeaderMatcher<T> - Class in org.springframework.integration.test.matcher
Are the MessageHeaders of a Message containing any entry or multiple that match?
HeaderPropagationAware - Interface in org.springframework.integration.handler
MessageHandlers implementing this interface can propagate headers from an input message to an output message.
headers(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(MapBuilder<?, String, Object>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(Map<String, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the Map; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(Map<String, Object>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the Map; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
The headers of the mapped request, narrowing the primary mapping.
headers() - Static method in class org.springframework.integration.mail.dsl.Mail
HEADERS - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
headersFunction(Function<MessageGroup, Map<String, Object>>) - Method in class org.springframework.integration.dsl.AggregatorSpec
Configure a Function to merge and compute headers for reply based on the completed MessageGroup.
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
 
headerToAdd - Variable in class org.springframework.integration.dsl.HeaderEnricherSpec
 
headerTypes - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
HeaderValueMessageProcessor<T> - Interface in org.springframework.integration.transformer.support
 
HeaderValueRouter - Class in org.springframework.integration.router
A Message Router that resolves the MessageChannel from a header value.
HeaderValueRouter(String) - Constructor for class org.springframework.integration.router.HeaderValueRouter
Create a router that uses the provided header name to lookup a channel.
HeaderValueRouterParser - Class in org.springframework.integration.config.xml
Parser for the <header-value-router/> element.
HeaderValueRouterParser() - Constructor for class org.springframework.integration.config.xml.HeaderValueRouterParser
 
HeapDumper - Class in org.springframework.integration.test.util
Use to take a heap dump programmatically.
HeapDumper() - Constructor for class org.springframework.integration.test.util.HeapDumper
 
HEARTBEAT - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
HistoryWritingMessagePostProcessor - Class in org.springframework.integration.history
 
HistoryWritingMessagePostProcessor() - Constructor for class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
HistoryWritingMessagePostProcessor(TrackableComponent) - Constructor for class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
HOST - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
HOST - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
HOST - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
HOSTNAME - Static variable in class org.springframework.integration.ip.IpHeaders
The host name from which a TCP message or UDP packet was received.
HsqlChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
HsqlChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
Http - Class in org.springframework.integration.http.dsl
The HTTP components Factory.
HTTP_REQUEST_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
HTTP_RESPONSE_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
HttpContextUtils - Class in org.springframework.integration.http.config
Utility class for accessing HTTP integration components from the BeanFactory.
HttpControllerEndpointSpec - Class in org.springframework.integration.http.dsl
HttpControllerEndpointSpec(HttpRequestHandlingController, String...) - Constructor for class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
 
HttpHeaders - Class in org.springframework.integration.http
 
HttpHeaders() - Constructor for class org.springframework.integration.http.HttpHeaders
 
HttpInboundEndpointParser - Class in org.springframework.integration.http.config
Parser for the 'inbound-channel-adapter' and 'inbound-gateway' elements of the 'http' namespace.
HttpInboundEndpointParser(boolean) - Constructor for class org.springframework.integration.http.config.HttpInboundEndpointParser
 
HttpInboundEndpointSupportSpec<S extends HttpInboundEndpointSupportSpec<S,E>,E extends BaseHttpInboundEndpoint> - Class in org.springframework.integration.http.dsl
 
HttpInboundEndpointSupportSpec(E, String...) - Constructor for class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
HttpInboundEndpointSupportSpec.CrossOriginSpec - Class in org.springframework.integration.http.dsl
A fluent API for the CrossOrigin.
HttpInboundEndpointSupportSpec.RequestMappingSpec - Class in org.springframework.integration.http.dsl
A fluent API for the RequestMapping.
HttpIntegrationConfigurationInitializer - Class in org.springframework.integration.http.config
The HTTP Integration infrastructure beanFactory initializer.
HttpIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.http.config.HttpIntegrationConfigurationInitializer
 
HttpMessageHandlerSpec - Class in org.springframework.integration.http.dsl
HttpMessageHandlerSpec(URI, RestTemplate) - Constructor for class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
 
HttpMessageHandlerSpec(String, RestTemplate) - Constructor for class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
 
HttpMessageHandlerSpec(Expression, RestTemplate) - Constructor for class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
 
httpMethod(HttpMethod) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify the HttpMethod for requests.
httpMethodExpression(Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify the SpEL Expression to determine HttpMethod at runtime.
httpMethodFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a Function to determine HttpMethod at runtime.
HttpNamespaceHandler - Class in org.springframework.integration.http.config
Namespace handler for Spring Integration's http namespace.
HttpNamespaceHandler() - Constructor for class org.springframework.integration.http.config.HttpNamespaceHandler
 
HttpOutboundChannelAdapterParser - Class in org.springframework.integration.http.config
Parser for the 'outbound-channel-adapter' element of the http namespace.
HttpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.http.config.HttpOutboundChannelAdapterParser
 
HttpOutboundGatewayParser - Class in org.springframework.integration.http.config
Parser for the 'outbound-gateway' element of the http namespace.
HttpOutboundGatewayParser() - Constructor for class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
HttpRequestExecutingMessageHandler - Class in org.springframework.integration.http.outbound
A MessageHandler implementation that executes HTTP requests by delegating to a RestTemplate instance.
HttpRequestExecutingMessageHandler(URI) - Constructor for class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI.
HttpRequestExecutingMessageHandler(String) - Constructor for class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI.
HttpRequestExecutingMessageHandler(Expression) - Constructor for class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI Expression.
HttpRequestExecutingMessageHandler(String, RestTemplate) - Constructor for class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI using a provided RestTemplate
HttpRequestExecutingMessageHandler(Expression, RestTemplate) - Constructor for class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI using a provided RestTemplate
HttpRequestHandlerEndpointSpec - Class in org.springframework.integration.http.dsl
HttpRequestHandlerEndpointSpec(HttpRequestHandlingMessagingGateway, String...) - Constructor for class org.springframework.integration.http.dsl.HttpRequestHandlerEndpointSpec
 
HttpRequestHandlingController - Class in org.springframework.integration.http.inbound
Inbound HTTP endpoint that implements Spring's Controller interface to be used with a DispatcherServlet front controller.
HttpRequestHandlingController() - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingController
 
HttpRequestHandlingController(boolean) - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingController
 
HttpRequestHandlingEndpointSupport - Class in org.springframework.integration.http.inbound
Base class for HTTP request handling endpoints.
HttpRequestHandlingEndpointSupport() - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Construct a gateway that will wait for the replyTimeout for a reply; if the timeout is exceeded a '500 Internal Server Error' status code is returned.
HttpRequestHandlingEndpointSupport(boolean) - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Construct a gateway.
HttpRequestHandlingMessagingGateway - Class in org.springframework.integration.http.inbound
Inbound Messaging Gateway that handles HTTP Requests.
HttpRequestHandlingMessagingGateway() - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
 
HttpRequestHandlingMessagingGateway(boolean) - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
 

I

id(String) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
id(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
 
id - Static variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
id(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Specify an id for the IntegrationFlow to register.
id(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
Specify an id for the IntegrationFlow to register.
id(String) - Method in class org.springframework.integration.dsl.EndpointSpec
 
id(String) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
Configure the component identifier.
id(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the component identifier.
id(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
 
id(String) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
id(String) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
 
id(String) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
id(String) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
id(String) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
 
id(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
id(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 
id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 
id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 
id(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
Return the MQTT message id.
ID - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
IDEMPOTENT_ENDPOINTS_MAPPING - Static variable in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
IdempotentReceiver - Annotation Type in org.springframework.integration.annotation
A method that has a MessagingAnnotation (@code @ServiceActivator, @Router etc.) that also has this annotation, has an IdempotentReceiverInterceptor applied to the associated MessageHandler.handleMessage(org.springframework.messaging.Message<?>) method.
IdempotentReceiverAutoProxyCreatorInitializer - Class in org.springframework.integration.config
The IntegrationConfigurationInitializer that populates the ConfigurableListableBeanFactory with an IdempotentReceiverAutoProxyCreator when IdempotentReceiverInterceptor BeanDefinitions and their mapping to Consumer Endpoints are present.
IdempotentReceiverAutoProxyCreatorInitializer() - Constructor for class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
IdempotentReceiverInterceptor - Class in org.springframework.integration.handler.advice
The MethodInterceptor implementation for the Idempotent Receiver E.I.
IdempotentReceiverInterceptor(MessageSelector) - Constructor for class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
IdempotentReceiverInterceptorParser - Class in org.springframework.integration.config.xml
Parser for the <idempotent-receiver/> element.
IdempotentReceiverInterceptorParser() - Constructor for class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
idExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression that will be evaluated to get the primaryKey for EntityManager.find(Class, Object)
idExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression that will be evaluated to get the primaryKey for EntityManager.find(Class, Object)
IdGeneratorConfigurer - Class in org.springframework.integration.config
 
IdGeneratorConfigurer() - Constructor for class org.springframework.integration.config.IdGeneratorConfigurer
 
IdGenerators - Class in org.springframework.integration.support
Alternative IdGenerator implementations.
IdGenerators() - Constructor for class org.springframework.integration.support.IdGenerators
 
IdGenerators.JdkIdGenerator - Class in org.springframework.integration.support
UUID.randomUUID()
IdGenerators.SimpleIncrementingIdGenerator - Class in org.springframework.integration.support
Based on the two AtomicLongs, for topBits and bottomBits, respectively.
idleConsumerLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The max for concurrent consumers number to use.
idleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
idleEventInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
How often to emit ListenerContainerIdleEvents in milliseconds.
idleEventInterval(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
Specify the idle interval before start sending idle events.
idleEventInterval(Long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
idleReplyContainerTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
idleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The the limit for idle task.
idleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
idleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
ignoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Specify whether empty String response payloads should be ignored.
ignoreExpressionFailures(boolean) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
ignoreFailures(boolean) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
ignoreHidden(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Configure an IgnoreHiddenFileListFilter if ignoreHidden == true.
IgnoreHiddenFileListFilter - Class in org.springframework.integration.file.filters
FileListFilter implementation that ignores any hidden files.
IgnoreHiddenFileListFilter() - Constructor for class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
 
ignoreSendFailures(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
imap(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
imapIdleAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
An ImapIdleChannelAdapterSpec factory using a default ImapMailReceiver.
imapIdleAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
A ImapIdleChannelAdapterSpec factory based on the provided url.
imapIdleAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.mail.dsl.Mail
An ImapIdleChannelAdapterSpec factory based on the provided ImapMailReceiver.
ImapIdleChannelAdapter - Class in org.springframework.integration.mail
An event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177).
ImapIdleChannelAdapter(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.ImapIdleChannelAdapter
 
ImapIdleChannelAdapter.ImapIdleExceptionEvent - Class in org.springframework.integration.mail
 
ImapIdleChannelAdapterParser - Class in org.springframework.integration.mail.config
Parser for the <imap-idle-channel-adapter> element in the 'mail' namespace.
ImapIdleChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
ImapIdleChannelAdapterSpec - Class in org.springframework.integration.mail.dsl
ImapIdleChannelAdapterSpec(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
ImapIdleChannelAdapterSpec(ImapMailReceiver, boolean) - Constructor for class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
imapInboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
imapInboundAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.mail.dsl.Mail
An ImapMailInboundChannelAdapterSpec factory based on the provided ImapMailReceiver.
imapInboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
A ImapMailInboundChannelAdapterSpec factory based on the provided url.
ImapMailInboundChannelAdapterSpec - Class in org.springframework.integration.mail.dsl
ImapMailInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
 
ImapMailInboundChannelAdapterSpec(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
 
ImapMailInboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
 
ImapMailReceiver - Class in org.springframework.integration.mail
A MailReceiver implementation for receiving mail messages from a mail server that supports the IMAP protocol.
ImapMailReceiver() - Constructor for class org.springframework.integration.mail.ImapMailReceiver
 
ImapMailReceiver(String) - Constructor for class org.springframework.integration.mail.ImapMailReceiver
 
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(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundAdapter(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundAdapter(URL, String) - Static method in class org.springframework.integration.feed.dsl.Feed
 
inboundAdapter(Resource, String) - Static method in class org.springframework.integration.feed.dsl.Feed
 
inboundAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileInboundChannelAdapterSpec builder for the FileReadingMessageSource.
inboundAdapter(File, Comparator<File>) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileInboundChannelAdapterSpec builder for the FileReadingMessageSource.
inboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundAdapter(SessionFactory<FTPFile>, Comparator<File>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundAdapter(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an inbound channel adapter using the supplied connection factory.
inboundAdapter(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an inbound channel adapter using the supplied connection factory.
inboundAdapter(int) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an inbound unicast channel adapter using the supplied port.
inboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsInboundChannelAdapterSpec.
inboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsInboundChannelAdapterSpec.
inboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaInboundChannelAdapterSpec builder instance based on the provided EntityManagerFactory.
inboundAdapter(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaInboundChannelAdapterSpec builder instance based on the provided EntityManager.
inboundAdapter(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaInboundChannelAdapterSpec builder instance based on the provided JpaOperations.
inboundAdapter(SessionFactory<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundAdapter(SessionFactory<ChannelSftp.LsEntry>, Comparator<File>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpInboundChannelAdapterSpec factory for an inbound channel adapter spec.
InboundChannelAdapter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of producing a Message or Message payload.
inboundChannelAdapter(String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpRequestHandlerEndpointSpec builder for one-way adapter based on the provided path array for mapping.
inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics.
inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics.
inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics with a custom ack callback factory.
inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics with a custom ack callback factory.
inboundChannelAdapter(R2dbcEntityOperations, String) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
Create an instance of R2dbcMessageSourceSpec for the provided R2dbcEntityOperations and query string.
inboundChannelAdapter(R2dbcEntityOperations, Function<R2dbcMessageSource.SelectCreator, StatementMapper.SelectSpec>) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
Create an instance of R2dbcMessageSourceSpec for the provided R2dbcEntityOperations and function to create a StatementMapper.SelectSpec instance.
inboundChannelAdapter(R2dbcEntityOperations, Expression) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
Create an instance of R2dbcMessageSourceSpec for the provided R2dbcEntityOperations and SpEL expression for query.
inboundChannelAdapter(String...) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxInboundEndpointSpec builder for one-way reactive adapter based on the provided path array for mapping.
inboundChannelAdapter(ZContext) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqMessageProducerSpec for the provided ZContext.
inboundChannelAdapter(ZContext, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqMessageProducerSpec for the provided ZContext and SocketType.
InboundChannelAdapterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @InboundChannelAdapter.
InboundChannelAdapterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
inboundControllerAdapter(String, String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpControllerEndpointSpec builder for one-way adapter based on the provided MVC viewName and path array for mapping.
inboundControllerAdapter(Expression, String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpControllerEndpointSpec builder for one-way adapter based on the provided SpEL expression and path array for mapping.
inboundControllerGateway(String, String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpControllerEndpointSpec builder for request-reply gateway based on the provided MVC viewName and path array for mapping.
inboundControllerGateway(Expression, String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpControllerEndpointSpec builder for request-reply gateway based on the provided SpEL expression and path array for mapping.
InboundFileSynchronizer - Interface in org.springframework.integration.file.remote.synchronizer
Strategy for synchronizing from a remote File system to a local directory.
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, Queue...) - 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(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundGateway(SimpleMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundGateway(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundGateway(DirectMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
inboundGateway(String...) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpRequestHandlerEndpointSpec builder for request-reply gateway based on the provided path array for mapping.
inboundGateway(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an inbound gateway using the supplied connection factory.
inboundGateway(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an inbound gateway using the supplied connection factory.
inboundGateway(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsInboundGatewaySpec.
inboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsInboundGatewaySpec.
inboundGateway(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsInboundGatewaySpec.
inboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided container and template.
inboundGateway(ConsumerFactory<K, V>, ContainerProperties, ProducerFactory<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided consumer factory, container properties and producer factory.
inboundGateway(KafkaMessageListenerContainerSpec<K, V>, KafkaTemplateSpec<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided container and template specs.
inboundGateway(String...) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
Create an RSocketInboundGatewaySpec builder for request-reply reactive gateway based on the provided path array for mapping.
inboundGateway(String...) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxInboundEndpointSpec builder for request-reply reactive gateway based on the provided path array for mapping.
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.
inboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Factory method for creating a basic inbound mapper instance.
InboundMessageMapper<T> - Interface in org.springframework.integration.mapping
Strategy interface for mapping from an Object to aMessage.
inboundMulticastAdapter(int, String) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an inbound multicast channel adapter using the supplied port and group.
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
 
inboundStreamingAdapter(RemoteFileTemplate<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpStreamingInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundStreamingAdapter(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpStreamingInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundStreamingAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpStreamingInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inboundStreamingAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>, Comparator<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpStreamingInboundChannelAdapterSpec factory for an inbound channel adapter spec.
inclusive() - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Include the length of the header in addition to the payload.
increment() - Method in interface org.springframework.integration.support.management.metrics.CounterFacade
 
increment() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
incrementAndGetConnectionSequence() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
incrementClientInstance() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
indexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
info() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
The factory to produce Log4j2LevelAdjuster instances for Level.INFO logging with the org.springframework.integration as default category.
init() - Method in class org.springframework.integration.amqp.config.AmqpNamespaceHandler
 
init() - Method in class org.springframework.integration.config.xml.IntegrationNamespaceHandler
 
init() - Method in class org.springframework.integration.event.config.EventNamespaceHandler
 
init() - Method in class org.springframework.integration.feed.config.FeedNamespaceHandler
 
init() - Method in class org.springframework.integration.file.config.FileNamespaceHandler
 
init(Tailer) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
init() - Method in class org.springframework.integration.ftp.config.FtpNamespaceHandler
 
init() - Method in class org.springframework.integration.gemfire.config.xml.GemfireIntegrationNamespaceHandler
 
init() - Method in class org.springframework.integration.groovy.config.GroovyNamespaceHandler
 
init() - Method in class org.springframework.integration.http.config.HttpNamespaceHandler
 
init() - Method in class org.springframework.integration.ip.config.IpNamespaceHandler
 
init() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
Initializes the SSLEngine and sets up the encryption/decryption buffers.
init() - Method in class org.springframework.integration.jdbc.config.JdbcNamespaceHandler
 
init() - Method in class org.springframework.integration.jms.config.JmsNamespaceHandler
 
init() - Method in class org.springframework.integration.jmx.config.JmxNamespaceHandler
 
init() - Method in class org.springframework.integration.jpa.config.xml.JpaNamespaceHandler
 
init() - Method in class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 
init() - Method in class org.springframework.integration.mail.config.MailNamespaceHandler
 
init() - Method in class org.springframework.integration.mongodb.config.MongoDbNamespaceHandler
 
init() - Method in class org.springframework.integration.mqtt.config.xml.MqttNamespaceHandler
 
init() - Method in class org.springframework.integration.redis.config.RedisNamespaceHandler
 
init() - Method in class org.springframework.integration.rmi.config.RmiNamespaceHandler
Deprecated.
 
init() - Method in class org.springframework.integration.rsocket.config.RSocketNamespaceHandler
 
init() - Method in class org.springframework.integration.scripting.config.jsr223.ScriptNamespaceHandler
 
init() - Method in class org.springframework.integration.security.config.IntegrationSecurityNamespaceHandler
 
init() - Method in class org.springframework.integration.sftp.config.SftpNamespaceHandler
 
init() - Method in class org.springframework.integration.stomp.config.StompNamespaceHandler
 
init() - Method in class org.springframework.integration.stream.config.StreamNamespaceHandler
 
init() - Method in class org.springframework.integration.syslog.config.SyslogNamespaceHandler
 
init() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
init() - Method in class org.springframework.integration.webflux.config.WebFluxNamespaceHandler
 
init() - Method in class org.springframework.integration.websocket.config.WebSocketNamespaceHandler
 
init() - Method in class org.springframework.integration.ws.config.WsNamespaceHandler
 
init() - Method in class org.springframework.integration.xml.config.IntegrationXmlNamespaceHandler
 
init() - Method in class org.springframework.integration.xmpp.config.XmppNamespaceHandler
 
init() - Method in class org.springframework.integration.zookeeper.config.xml.ZookeeperNamespaceHandler
 
initCorsConfiguration(Object, Method, RequestMappingInfo) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
initCorsConfiguration(Object, Method, RequestMappingInfo) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
initialize(String) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in interface org.springframework.integration.config.IntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.dsl.context.DslIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.http.config.HttpIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.jmx.config.JmxIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.security.config.SecurityIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.webflux.config.WebFluxIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.websocket.config.WebSocketIntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.ws.config.WsIntegrationConfigurationInitializer
 
initializeConnection(TcpConnectionSupport, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Transfers attributes such as (de)serializers, singleUse etc to a new connection.
initializeConnection(TcpConnectionSupport, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Transfers attributes such as (de)serializer, mapper etc to a new connection.
initialized(ServerSession, int) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
injectConstructorWithAdapter(String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
injectPropertyWithAdapter(String, String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
InnerHandler(String, String) - Constructor for class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
 
INPUT_CHANNEL - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
 
INPUT_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
The context key for the message object.
inputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Subclasses can override this, for example to wrap the input stream.
inputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Subclasses can override this, for example to wrap the input stream.
InputStreamCallback - Interface in org.springframework.integration.file.remote
Callback for stream-based file retrieval using a RemoteFileOperations.
INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
A single reusable instance.
INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayLfSerializer
A single reusable instance.
INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
A single reusable instance that does not treat timeouts as end of message.
INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
A single reusable instance.
INSTANCE - Static variable in class org.springframework.integration.util.JavaUtils
The singleton instance of this utility class.
INTEGRATION_CONFIGURATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_CONVERSION_SERVICE_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
 
INTEGRATION_DATATYPE_CHANNEL_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_FIXED_SUBSCRIBER_CHANNEL_BPP_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_GLOBAL_PROPERTIES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_GRAPH_SERVER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_HEADER_CHANNEL_REGISTRY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_LIFECYCLE_ROLE_CONTROLLER - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_MESSAGE_BUILDER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
 
INTEGRATION_MESSAGE_HISTORY_CONFIGURER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_PROPERTIES_PREFIX - Static variable in class org.springframework.integration.context.IntegrationProperties
 
INTEGRATION_SIMPLE_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
integrationComponents - Variable in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
IntegrationComponentScan - Annotation Type in org.springframework.integration.annotation
Configures component scanning directives for use with Configuration classes.
IntegrationComponentScanRegistrar - Class in org.springframework.integration.config
ImportBeanDefinitionRegistrar implementation to scan and register Integration specific components.
IntegrationComponentScanRegistrar() - Constructor for class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
IntegrationComponentSpec<S extends IntegrationComponentSpec<S,T>,T> - Class in org.springframework.integration.dsl
The common Builder abstraction.
IntegrationComponentSpec() - Constructor for class org.springframework.integration.dsl.IntegrationComponentSpec
 
IntegrationConfigurationBeanFactoryPostProcessor - Class in org.springframework.integration.config
BeanDefinitionRegistryPostProcessor to apply external Integration infrastructure configurations via loading IntegrationConfigurationInitializer implementations using SpringFactoriesLoader.
IntegrationConfigurationBeanFactoryPostProcessor() - Constructor for class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
IntegrationConfigurationInitializer - Interface in org.springframework.integration.config
The strategy to initialize the external Integration infrastructure (@{code BeanFactoryPostProcessor}s, global beans etc.) in the provided beanFactory.
IntegrationConfigUtils - Class in org.springframework.integration.config
Shared utility methods for Integration configuration.
IntegrationConsumer - Interface in org.springframework.integration.endpoint
Message consumers implement this interface, the message handler within a consumer may or may not emit output messages.
IntegrationContextUtils - Class in org.springframework.integration.context
Utility methods for accessing common integration components from the BeanFactory.
IntegrationContextUtils() - Constructor for class org.springframework.integration.context.IntegrationContextUtils
 
IntegrationConverter - Annotation Type in org.springframework.integration.config
A marker annotation (an analogue of <int:converter/>) to register Converter, GenericConverter or ConverterFactory beans for the integrationConversionService.
IntegrationConverterInitializer - Class in org.springframework.integration.config
 
IntegrationConverterInitializer() - Constructor for class org.springframework.integration.config.IntegrationConverterInitializer
 
IntegrationEvaluationContextFactoryBean - Class in org.springframework.integration.config
FactoryBean to populate StandardEvaluationContext instances enhanced with: a BeanFactoryResolver.
IntegrationEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
IntegrationEvent - Class in org.springframework.integration.events
Base class for all ApplicationEvents generated by the framework.
IntegrationEvent(Object) - Constructor for class org.springframework.integration.events.IntegrationEvent
 
IntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.events.IntegrationEvent
 
IntegrationFlow - Interface in org.springframework.integration.dsl
The main Integration DSL abstraction.
IntegrationFlowAdapter - Class in org.springframework.integration.dsl
The base Adapter class for the IntegrationFlow abstraction.
IntegrationFlowAdapter() - Constructor for class org.springframework.integration.dsl.IntegrationFlowAdapter
 
IntegrationFlowBeanPostProcessor - Class in org.springframework.integration.dsl.context
A BeanPostProcessor to parse IntegrationFlow beans and register their components as beans in the provided BeanFactory, if necessary.
IntegrationFlowBeanPostProcessor() - Constructor for class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
 
IntegrationFlowBuilder - Class in org.springframework.integration.dsl
 
IntegrationFlowContext - Interface in org.springframework.integration.dsl.context
A public API for dynamic (manual) registration of IntegrationFlows, not via standard bean registration phase.
IntegrationFlowContext.IntegrationFlowRegistration - Interface in org.springframework.integration.dsl.context
 
IntegrationFlowContext.IntegrationFlowRegistrationBuilder - Interface in org.springframework.integration.dsl.context
A Builder pattern implementation for the options to register IntegrationFlow in the application context.
IntegrationFlowDefinition<B extends IntegrationFlowDefinition<B>> - Class in org.springframework.integration.dsl
The BaseIntegrationFlowDefinition extension for syntax sugar with generics for some type-based EIP-methods when an expected payload type is assumed from upstream.
IntegrationFlowExtension<B extends IntegrationFlowExtension<B>> - Class in org.springframework.integration.dsl
An IntegrationFlowDefinition extension for custom Java DSL operators and reusable solutions.
IntegrationFlowExtension() - Constructor for class org.springframework.integration.dsl.IntegrationFlowExtension
 
IntegrationFlows - Class in org.springframework.integration.dsl
The central factory for fluent IntegrationFlowBuilder API.
IntegrationGraphController - Class in org.springframework.integration.http.management
The REST Controller to provide the management API over IntegrationGraphServer.
IntegrationGraphController(IntegrationGraphServer) - Constructor for class org.springframework.integration.http.management.IntegrationGraphController
 
IntegrationGraphControllerParser - Class in org.springframework.integration.http.config
The BeanDefinitionParser for the <int-http:graph-controller> component.
IntegrationGraphControllerParser() - Constructor for class org.springframework.integration.http.config.IntegrationGraphControllerParser
 
IntegrationGraphServer - Class in org.springframework.integration.graph
Builds the runtime object model graph.
IntegrationGraphServer() - Constructor for class org.springframework.integration.graph.IntegrationGraphServer
 
IntegrationHandlerResultHandler - Class in org.springframework.integration.webflux.inbound
A HandlerResultHandler implementation to handle the result of the WebFluxInboundEndpoint execution.
IntegrationHandlerResultHandler() - Constructor for class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
 
IntegrationInboundManagement - Interface in org.springframework.integration.support.management
Marker interface indicating that this IntegrationManagement component initiates message flow.
IntegrationJmxAttributeSource - Class in org.springframework.integration.monitor
IntegrationJmxAttributeSource() - Constructor for class org.springframework.integration.monitor.IntegrationJmxAttributeSource
 
IntegrationManagedResource - Annotation Type in org.springframework.integration.support.management
Clone of ManagedResource limiting beans thus annotated so that they will only be exported by the IntegrationMBeanExporter and prevented from being exported by other MBeanExporters (if present).
IntegrationManagement - Interface in org.springframework.integration.support.management
Base interface for Integration managed components.
IntegrationManagement.ManagementOverrides - Class in org.springframework.integration.support.management
Toggles to inform the management configurer to not set these properties since the user has manually configured them in a bean definition.
IntegrationManagementConfiguration - Class in org.springframework.integration.config
@Configuration class that registers a IntegrationManagementConfigurer bean.
IntegrationManagementConfiguration() - Constructor for class org.springframework.integration.config.IntegrationManagementConfiguration
 
IntegrationManagementConfigurer - Class in org.springframework.integration.config
Configures beans that implement IntegrationManagement.
IntegrationManagementConfigurer() - Constructor for class org.springframework.integration.config.IntegrationManagementConfigurer
 
IntegrationManagementParser - Class in org.springframework.integration.config.xml
Parser for the <management/> element.
IntegrationManagementParser() - Constructor for class org.springframework.integration.config.xml.IntegrationManagementParser
 
IntegrationMBeanExportConfiguration - Class in org.springframework.integration.jmx.config
@Configuration class that registers a IntegrationMBeanExporter bean.
IntegrationMBeanExportConfiguration() - Constructor for class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
 
IntegrationMBeanExporter - Class in org.springframework.integration.monitor
MBean exporter for Spring Integration components in an existing application.
IntegrationMBeanExporter() - Constructor for class org.springframework.integration.monitor.IntegrationMBeanExporter
 
IntegrationMessageHeaderAccessor - Class in org.springframework.integration
Adds standard SI Headers.
IntegrationMessageHeaderAccessor(Message<?>) - Constructor for class org.springframework.integration.IntegrationMessageHeaderAccessor
 
IntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
Namespace handler for the integration namespace.
IntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceHandler
 
IntegrationNamespaceUtils - Class in org.springframework.integration.config.xml
Shared utility methods for integration namespace parsers.
IntegrationNamespaceUtils() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
IntegrationNode - Class in org.springframework.integration.graph
Base class for all nodes.
IntegrationNode(int, String, Object) - Constructor for class org.springframework.integration.graph.IntegrationNode
 
IntegrationObjectSupport - Class in org.springframework.integration.context
A base class that provides convenient access to the bean factory as well as TaskScheduler and ConversionService instances.
IntegrationObjectSupport() - Constructor for class org.springframework.integration.context.IntegrationObjectSupport
 
IntegrationPattern - Interface in org.springframework.integration
Indicates that a component implements some Enterprise Integration Pattern.
IntegrationPatternType - Enum in org.springframework.integration
The Enterprise Integration Pattern types.
IntegrationPatternType.IntegrationPatternCategory - Enum in org.springframework.integration
The Enterprise Integration Pattern categories.
IntegrationProperties - Class in org.springframework.integration.context
Utility class to encapsulate infrastructure Integration properties constants and their default values from resources 'META-INF/spring.integration.default.properties'.
IntegrationReactiveUtils - Class in org.springframework.integration.util
Utilities for adapting integration components to/from reactive types.
IntegrationRegistrar - Class in org.springframework.integration.config
ImportBeanDefinitionRegistrar implementation that configures integration infrastructure.
IntegrationRegistrar() - Constructor for class org.springframework.integration.config.IntegrationRegistrar
 
IntegrationRequestMappingHandlerMapping - Class in org.springframework.integration.http.inbound
The HandlerMapping implementation that detects and registers RequestMappingInfos for HttpRequestHandlingEndpointSupport from a Spring Integration HTTP configuration of <inbound-channel-adapter/> and <inbound-gateway/> elements.
IntegrationRequestMappingHandlerMapping() - Constructor for class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
IntegrationResourceHolder - Class in org.springframework.integration.transaction
An implementation of the ResourceHolder which holds an instance of the current Message and the synchronization resource
IntegrationResourceHolder() - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolder
 
IntegrationResourceHolderSynchronization - Class in org.springframework.integration.transaction
IntegrationResourceHolderSynchronization(IntegrationResourceHolder, Object) - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
IntegrationRSocketEndpoint - Interface in org.springframework.integration.rsocket
A marker ReactiveMessageHandler extension interface for Spring Integration inbound endpoints.
IntegrationSecurityNamespaceHandler - Class in org.springframework.integration.security.config
Namespace handler for the security namespace.
IntegrationSecurityNamespaceHandler() - Constructor for class org.springframework.integration.security.config.IntegrationSecurityNamespaceHandler
 
IntegrationSimpleEvaluationContextFactoryBean - Class in org.springframework.integration.config
FactoryBean to populate SimpleEvaluationContext instances enhanced with: a TypeConverter based on the ConversionService from the application context.
IntegrationSimpleEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
IntegrationStompHeaders - Class in org.springframework.integration.stomp.support
The STOMP headers with Integration-friendly stomp_ prefix.
IntegrationStompHeaders() - Constructor for class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
IntegrationUtils - Class in org.springframework.integration.support.utils
General utility methods.
IntegrationWebExchangeBindException - Exception in org.springframework.integration.http.support
A WebExchangeBindException extension for validation error with a failed message context.
IntegrationWebExchangeBindException(String, Object, BindingResult) - Constructor for exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
IntegrationWebSocketContainer - Class in org.springframework.integration.websocket
The high-level 'connection factory pattern' contract over low-level Web-Socket configuration.
IntegrationWebSocketContainer() - Constructor for class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
IntegrationXmlNamespaceHandler - Class in org.springframework.integration.xml.config
 
IntegrationXmlNamespaceHandler() - Constructor for class org.springframework.integration.xml.config.IntegrationXmlNamespaceHandler
 
interactionModel(RSocketInteractionModel) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure an RSocketInteractionModel for the RSocket request type.
interactionModel(Function<Message<P>, ?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a Function to evaluate an RSocketInteractionModel for the RSocket request type at runtime against a request message.
interactionModel(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate an RSocketInteractionModel for the RSocket request type at runtime against a request message.
interactionModel(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate an RSocketInteractionModel for the RSocket request type at runtime against a request message.
interactionModels(RSocketInteractionModel...) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
Configure a set of RSocketInteractionModel the endpoint is going to be mapped onto.
intercept(ChannelInterceptor...) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Add one or more ChannelInterceptor implementations to the current BaseIntegrationFlowDefinition.currentMessageChannel, in the given order, after any interceptors already registered.
interceptor(ChannelInterceptor...) - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
INTERCEPTOR_FACTORY_CHAIN - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
interceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
interceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Specify the ClientInterceptors to use.
interceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify the ClientInterceptors to use.
intExpression(String) - Static method in class org.springframework.integration.expression.ExpressionUtils
Return a ValueExpression for a simple literal, otherwise a SpelExpression.
invoke(MethodInvocation) - Method in class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
invoke(MethodInvocation) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
 
invoke(RemoteFileOperations.OperationsCallback<F, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Invoke the callback and run all operations on the template argument in a dedicated thread-bound session and reliably close the it afterwards.
invoke(RemoteFileOperations.OperationsCallback<F, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.HandleMessageAdviceAdapter
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.ReactiveRequestHandlerAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.scheduling.PollSkipAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
invoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
IO_EXCEPTION - Static variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
IP_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The ip address from which a TCP message or UDP packet was received.
IP_PREFIX - Static variable in class org.springframework.integration.ip.IpHeaders
The "ip_" prefix for UDP and TCP headers.
IpAdapterParserUtils - Class in org.springframework.integration.ip.config
Utility methods and constants for IP adapter parsers.
IpHeaders - Class in org.springframework.integration.ip
Headers for Messages mapped from IP datagram packets.
IpIntegrationEvent - Class in org.springframework.integration.ip.event
 
IpIntegrationEvent(Object) - Constructor for class org.springframework.integration.ip.event.IpIntegrationEvent
 
IpIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.event.IpIntegrationEvent
 
IpNamespaceHandler - Class in org.springframework.integration.ip.config
Namespace handler for Spring Integration's ip namespace.
IpNamespaceHandler() - Constructor for class org.springframework.integration.ip.config.IpNamespaceHandler
 
is(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
IS_POSIX - Static variable in class org.springframework.integration.file.support.FileUtils
 
isAbstract() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
isAckDeferred() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
isAckDeferred() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
isAcknowledge() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
isAcknowledged() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
Implementations must implement this to indicate when the ack has been processed by the user so that the framework can auto-ack if needed.
isAcknowledged() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
isAcknowledged() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
isAcquired(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
isAcquired(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
isActive() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
isActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isAnnotation() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
isAppend() - Method in class org.springframework.integration.ftp.server.FileWrittenEvent
 
isAsync() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
isAsyncExecutorExplicitlySet() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
isAutoAck() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
Return true if this acknowledgment supports auto ack when it has not been already ack'd by the application.
isAutoAck() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
isAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
isAutoReceiptEnabled() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
isAutoReceiptEnabled() - Method in interface org.springframework.integration.stomp.StompSessionManager
 
isAutoStartup() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
isAutoStartup() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
isAutoStartup() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
isAutoStartup() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
isAutoStartup() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
isAutoStartup() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
isAutoStartup() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
isAutoStartup() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
isAutoStartup() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
isAutoStartup() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
isAutoStartup() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isAutoStartup() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
isAutoStartup() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
isAutoStartup() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
isAutoStartup() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
isAutoStartup() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
isAutoStartup() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
isBroadcast() - Method in interface org.springframework.integration.channel.BroadcastCapableChannel
Return a state of this channel in regards of broadcasting capabilities.
isBroadcast() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
isChmodCapable() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
isChmodCapable() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
isChmodCapable() - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
isChmodCapable() - Method in class org.springframework.integration.ftp.outbound.FtpMessageHandler
 
isChmodCapable() - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
isChmodCapable() - Method in class org.springframework.integration.sftp.outbound.SftpMessageHandler
 
isClientMode() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
 
isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
isClientModeConnected() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
 
isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
isClientSet() - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
isClientSet() - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
 
isClientSet() - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
isClosed() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
isComplete() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
isComplete() - Method in interface org.springframework.integration.store.MessageGroup
 
isComplete() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
isComplete() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
isConnected() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
 
isConnected() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
isConnected() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
isConnected() - Method in interface org.springframework.integration.stomp.StompSessionManager
 
isConnected() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
Return true if the ClientWebSocketContainer.clientSession is opened.
isDefaultToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
isDigit() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
isDirectory(F) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
Subclasses must implement this method to indicate whether the file is a directory or not.
isDirectory(File) - Method in class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
isDirectory(File) - Method in class org.springframework.integration.file.filters.SimplePatternFileListFilter
 
isDirectory(F) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
isDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
 
isDirectory(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
 
isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
 
isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
 
isDirectory() - Method in class org.springframework.integration.ftp.server.PathRemovedEvent
 
isDirectory() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
isDirectory(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
isDirectory(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
 
isDirectory(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
isDirectory(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
 
isDirectory() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
 
isDirectory() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
isDiscarded() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
Deprecated.
 
isEligibleAttribute(String) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
isEmpty() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
isEmpty() - Method in class org.springframework.integration.history.MessageHistory
 
isEmpty() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
isEmptyPayload(Object) - Method in class org.springframework.integration.support.NullAwarePayloadArgumentResolver
 
isEqual(F, String) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Override this method if you wish to use something other than the modified timestamp to determine equality.
isExpectReply() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
isExpectReply() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
isExpireGroupsUponCompletion() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isExpireGroupsUponCompletion() - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
 
isExtractPayload() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
isFair() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
isFile(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
isFile(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
isFile(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
isFinal() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
isFixedRate() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Return whether this trigger is fixed rate.
isFrameContainingXBeforeFrameContainingY(String, String, StackTraceElement[]) - Static method in class org.springframework.integration.util.StackTraceUtils
Traverses the stack trace element array looking for instances that contain the first or second Strings in the className property.
isHandler(Class<?>) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
isHandler(Class<?>) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
isHeadersMappedLast() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
isImplicitChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
isInclusive() - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Return true if the length header value includes its own length.
isIndependent() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
isInitialized() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Return the status of this component if it has been initialized already.
isInitialized() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
isInitialized() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
isInitialized() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
isInputShutdown() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
isInterface() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonPresent
 
isKotlinFaction0(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Check if class is kotlin.jvm.functions.Function0.
isKotlinFaction1(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Check if class is kotlin.jvm.functions.Function1.
isKotlinUnit(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Check if class is kotlin.Unit.
isLambda(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Check if class is Java lambda.
isLazyConnect() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
isLeader() - Method in interface org.springframework.integration.leader.Context
Checks if the Candidate this context was passed to is the leader.
isLeader() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
 
isLink() - Method in interface org.springframework.integration.file.remote.FileInfo
 
isLink(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
isLink(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
isLink() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
isLink(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
isLink() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
isListening() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
isListening() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
isListening() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
isListening() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
isListening() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
isListening() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
isListening() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
isLockable(File) - Method in interface org.springframework.integration.file.FileLocker
Checks whether the file passed in can be locked by this locker.
isLockable(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
 
isLockRegistrySet() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isLoggingEnabled() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
isLoggingEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isLoggingEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isLoggingEnabled() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
isLoggingEnabled() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
isLoggingEnabled() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
isLoggingEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
Return whether logging is enabled.
isLongLived() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
isLongLived() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
isLost() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
isMapToPayload() - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
isModified() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
isNegated() - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
Return true if this match should be explicitly excluded from the mapping.
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
isNoReadErrorOnClose() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
isolation(Isolation) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
isOpen() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
isOpen() - Method in interface org.springframework.integration.file.remote.session.Session
 
isOpen() - Method in class org.springframework.integration.ftp.session.FtpSession
 
isOpen() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
isOpen() - Method in class org.springframework.integration.sftp.session.SftpSession
 
isOutputChannelRequired() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
isOutputShutdown() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
isOverwrite() - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
isOverwrite() - Method in interface org.springframework.integration.transformer.support.HeaderValueMessageProcessor
 
isOverwrite() - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
isPaused() - Method in interface org.springframework.integration.core.Pausable
Check if the endpoint is paused.
isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
isPayloadAsBytes() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
isPriorityEnabled() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
isPriorityEnabled() - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
isPriorityEnabled() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
isPriorityEnabled() - Method in interface org.springframework.integration.store.PriorityCapableChannelMessageStore
 
isPublishFailedEvents() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
isPushbackCapable() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
 
isRawMessageHeader() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
isRawMessageHeader() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
isReactive() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
isReactive() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
isReactive() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
isReadable(HttpMethod) - Static method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Checks if the request has a readable body (not a GET, HEAD, or OPTIONS request).
isReadOnly(String) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
isReceive() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
isReceiveOnlyAdvice(Advice) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return true if this advice should be applied only to the AbstractPollingEndpoint.receiveMessage() operation rather than the whole poll.
isReleaseLockBeforeSend() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isReleasePartialSequences() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isRetained() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
isRolledBack() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
isRolledBack() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
isRunning() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isRunning() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
isRunning() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
isRunning() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
isRunning() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
isRunning() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
isRunning() - Method in class org.springframework.integration.channel.interceptor.WireTap
Check whether the wire tap is currently running.
isRunning() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
isRunning() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
isRunning() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
isRunning() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
isRunning() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
isRunning() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
isRunning() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
isRunning() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
isRunning() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
isRunning() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
isRunning() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
isRunning() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
isRunning() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
isRunning() - Method in class org.springframework.integration.filter.MessageFilter
 
isRunning() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
isRunning() - Method in class org.springframework.integration.handler.MessageHandlerChain
SmartLifecycle implementation (delegates to the MessageHandlerChain.handlers)
isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
isRunning() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
isRunning() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
isRunning() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
isRunning() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
isRunning() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
isRunning() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
Returns true if all factories are running
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
isRunning() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
isRunning() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
isRunning() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
isRunning() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
isRunning() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
isRunning() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
isRunning() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
isRunning() - Method in class org.springframework.integration.monitor.ManagedEndpoint
Deprecated.
 
isRunning() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
isRunning() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
isRunning() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
isRunning() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
isRunning() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
isRunning() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
isRunning() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isRunning() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
isRunning() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
 
isRunning() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
isRunning() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
isRunning() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
isRunning() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
isRunning() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
isRunning() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
isRunning() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
isRunning() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
isRunning() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
isRunning() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
isRunning() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
isRunning() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
isSend() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
isSendPartialResultOnExpiry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isSequenceAware() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isServer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
isServer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
isServer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
isSessionTransacted() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
isSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
 
isSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
isShouldMarkMessagesAsRead() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
isShouldMarkMessagesAsRead() - Method in class org.springframework.integration.mail.ImapMailReceiver
Check if messages should be marked as read.
isShuttingDown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
isSingleton() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
isSingleton() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
isSingleton() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
isStale(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when an idle item is retrieved from the pool.
isSyncExecutor() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
isSyncExecutor() - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
isTimeoutOnIdle() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
isUseIdAsPrefix(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Return true to prefix flow bean names with the flow id and a period.
isUseIdAsPrefix(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
 
isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
isUseWatchService() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
isUsingReplyProducer() - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this to signal that this channel adapter is actually using a AbstractReplyProducingMessageHandler while it is not possible for this parser to determine that because, say, a FactoryBean is being used.
isUsingReplyProducer() - Method in class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
 
isUsingReplyProducer() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
 
isVoid() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
iterator() - Method in class org.springframework.integration.history.MessageHistory
 
iterator() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
iterator() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ArrayNodeAsList
 
iterator() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
iterator() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
iterator() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
iterator() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
iterator() - Method in class org.springframework.integration.store.MessageGroupQueue
 
iterator() - Method in interface org.springframework.integration.store.MessageGroupStore
 
iterator() - Method in class org.springframework.integration.store.SimpleMessageStore
 

J

Jackson2JsonMessageParser - Class in org.springframework.integration.support.json
JsonInboundMessageMapper.JsonMessageParser implementation that parses JSON messages and builds a Message with the specified payload type from provided JsonInboundMessageMapper.
Jackson2JsonMessageParser() - Constructor for class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
Jackson2JsonMessageParser(Jackson2JsonObjectMapper) - Constructor for class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
Jackson2JsonObjectMapper - Class in org.springframework.integration.support.json
Jackson 2 JSON-processor (@link https://github.com/FasterXML) JsonObjectMapper implementation.
Jackson2JsonObjectMapper() - Constructor for class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
Jackson2JsonObjectMapper(ObjectMapper) - Constructor for class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
JacksonJsonUtils - Class in org.springframework.integration.support.json
Utility methods for Jackson.
JacksonPresent - Class in org.springframework.integration.support.json
The utility to check if Jackson JSON processor is present in the classpath.
javaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
javaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
The Java Mail Authenticator.
javaMailProperties(Properties) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Configure the javaMailProperties by invoking a Consumer callback which is invoked with a PropertiesBuilder.
javaMailProperties(Properties) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
The Java Mail properties.
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Configure the javaMailProperties by invoking a Consumer callback which is invoked with a PropertiesBuilder.
javaMailProperties(Properties) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the javamail properties.
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set a Consumer that will be invoked with a PropertiesBuilder; most often used with a lambda expression.
JavaUtils - Class in org.springframework.integration.util
Chained utility methods to simplify some Java repetitive code.
JAXB_PRESENT - Static variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
JdbcChannelMessageStore - Class in org.springframework.integration.jdbc.store
Channel-specific implementation of MessageGroupStore using a relational database via JDBC.
JdbcChannelMessageStore() - Constructor for class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Convenient constructor for configuration use.
JdbcChannelMessageStore(DataSource) - Constructor for class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Create a MessageStore with all mandatory properties.
JdbcLockRegistry - Class in org.springframework.integration.jdbc.lock
An ExpirableLockRegistry using a shared database to co-ordinate the locks.
JdbcLockRegistry(LockRepository) - Constructor for class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
JdbcMessageHandler - Class in org.springframework.integration.jdbc
A message handler that executes an SQL update.
JdbcMessageHandler(DataSource, String) - Constructor for class org.springframework.integration.jdbc.JdbcMessageHandler
Constructor taking DataSource from which the DB Connection can be obtained and the select query to execute to retrieve new rows.
JdbcMessageHandler(JdbcOperations, String) - Constructor for class org.springframework.integration.jdbc.JdbcMessageHandler
Constructor taking JdbcOperations instance to use for query execution and the select query to execute to retrieve new rows.
JdbcMessageHandlerParser - Class in org.springframework.integration.jdbc.config
 
JdbcMessageHandlerParser() - Constructor for class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
JdbcMessageStore - Class in org.springframework.integration.jdbc.store
Implementation of MessageStore using a relational database via JDBC.
JdbcMessageStore(DataSource) - Constructor for class org.springframework.integration.jdbc.store.JdbcMessageStore
Create a MessageStore with all mandatory properties.
JdbcMessageStore(JdbcOperations) - Constructor for class org.springframework.integration.jdbc.store.JdbcMessageStore
Create a MessageStore with all mandatory properties.
JdbcMessageStoreParser - Class in org.springframework.integration.jdbc.config
Parser for JdbcMessageStore.
JdbcMessageStoreParser() - Constructor for class org.springframework.integration.jdbc.config.JdbcMessageStoreParser
 
JdbcMetadataStore - Class in org.springframework.integration.jdbc.metadata
Implementation of ConcurrentMetadataStore using a relational database via JDBC.
JdbcMetadataStore(DataSource) - Constructor for class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
Instantiate a JdbcMetadataStore using provided dataSource DataSource.
JdbcMetadataStore(JdbcOperations) - Constructor for class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
Instantiate a JdbcMetadataStore using provided jdbcOperations JdbcOperations.
JdbcNamespaceHandler - Class in org.springframework.integration.jdbc.config
Namespace handler for the integration JDBC schema.
JdbcNamespaceHandler() - Constructor for class org.springframework.integration.jdbc.config.JdbcNamespaceHandler
 
JdbcOutboundGateway - Class in org.springframework.integration.jdbc
 
JdbcOutboundGateway(DataSource, String) - Constructor for class org.springframework.integration.jdbc.JdbcOutboundGateway
 
JdbcOutboundGateway(DataSource, String, String) - Constructor for class org.springframework.integration.jdbc.JdbcOutboundGateway
 
JdbcOutboundGateway(JdbcOperations, String) - Constructor for class org.springframework.integration.jdbc.JdbcOutboundGateway
 
JdbcOutboundGateway(JdbcOperations, String, String) - Constructor for class org.springframework.integration.jdbc.JdbcOutboundGateway
 
JdbcOutboundGatewayParser - Class in org.springframework.integration.jdbc.config
 
JdbcOutboundGatewayParser() - Constructor for class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
JdbcPollingChannelAdapter - Class in org.springframework.integration.jdbc
A polling channel adapter that creates messages from the payload returned by executing a select query.
JdbcPollingChannelAdapter(DataSource, String) - Constructor for class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Constructor taking DataSource from which the DB Connection can be obtained and the select query to execute to retrieve new rows.
JdbcPollingChannelAdapter(JdbcOperations, String) - Constructor for class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Constructor taking JdbcOperations instance to use for query execution and the select query to execute to retrieve new rows.
JdbcPollingChannelAdapterParser - Class in org.springframework.integration.jdbc.config
JdbcPollingChannelAdapterParser() - Constructor for class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
JdbcTypesEnum - Enum in org.springframework.integration.jdbc.config
This Enumeration provides a handy wrapper around Types.
JdkIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.JdkIdGenerator
 
Jms - Class in org.springframework.integration.jms.dsl
Factory class for JMS components.
JmsAdapterUtils - Class in org.springframework.integration.jms.util
 
JmsAdapterUtils() - Constructor for class org.springframework.integration.jms.util.JmsAdapterUtils
 
JmsChannelFactoryBean - Class in org.springframework.integration.jms.config
 
JmsChannelFactoryBean() - Constructor for class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
JmsChannelFactoryBean(boolean) - Constructor for class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
jmsChannelFactoryBean - Variable in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
JmsChannelParser - Class in org.springframework.integration.jms.config
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration JMS namespace.
JmsChannelParser() - Constructor for class org.springframework.integration.jms.config.JmsChannelParser
 
JmsDefaultListenerContainerSpec - Class in org.springframework.integration.jms.dsl
JmsDefaultListenerContainerSpec() - Constructor for class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
 
JmsDestinationAccessorSpec<S extends JmsDestinationAccessorSpec<S,A>,A extends JmsDestinationAccessor> - Class in org.springframework.integration.jms.dsl
JmsDestinationAccessorSpec(A) - Constructor for class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
 
JmsDestinationPollingSource - Class in org.springframework.integration.jms
A source for receiving JMS Messages with a polling listener.
JmsDestinationPollingSource(JmsTemplate) - Constructor for class org.springframework.integration.jms.JmsDestinationPollingSource
 
JmsHeaderEnricherParser - Class in org.springframework.integration.jms.config
Header enricher for JMS specific values.
JmsHeaderEnricherParser() - Constructor for class org.springframework.integration.jms.config.JmsHeaderEnricherParser
 
JmsHeaderMapper - Class in org.springframework.integration.jms
Strategy interface for mapping integration Message headers to an outbound JMS Message (e.g.
JmsHeaderMapper() - Constructor for class org.springframework.integration.jms.JmsHeaderMapper
 
JmsInboundChannelAdapterParser - Class in org.springframework.integration.jms.config
Parser for the <inbound-channel-adapter/> element of the 'jms' namespace.
JmsInboundChannelAdapterParser() - Constructor for class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
JmsInboundChannelAdapterSpec<S extends JmsInboundChannelAdapterSpec<S>> - Class in org.springframework.integration.jms.dsl
JmsInboundChannelAdapterSpec(JmsTemplate) - Constructor for class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
 
JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware - Class in org.springframework.integration.jms.dsl
JmsInboundChannelSpecTemplateAware(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
 
JmsInboundGateway - Class in org.springframework.integration.jms
A wrapper around the JmsMessageDrivenEndpoint implementing MessagingGatewaySupport.
JmsInboundGateway(AbstractMessageListenerContainer, ChannelPublishingJmsMessageListener) - Constructor for class org.springframework.integration.jms.JmsInboundGateway
 
JmsInboundGatewayListenerContainerSpec(S) - Constructor for class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
JmsInboundGatewaySpec<S extends JmsInboundGatewaySpec<S>> - Class in org.springframework.integration.jms.dsl
JmsInboundGatewaySpec(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.jms.dsl
JmsListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.jms.dsl
JmsListenerContainerSpec(Class<C>) - Constructor for class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
JmsMessageChannelSpec<S extends JmsMessageChannelSpec<S,T>,T extends AbstractJmsChannel> - Class in org.springframework.integration.jms.dsl
JmsMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Configure the MessageConverter used for both sending and receiving.
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
JmsMessageDrivenChannelAdapterListenerContainerSpec(S) - Constructor for class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
 
JmsMessageDrivenChannelAdapterSpec<S extends JmsMessageDrivenChannelAdapterSpec<S>> - Class in org.springframework.integration.jms.dsl
JmsMessageDrivenChannelAdapterSpec(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
 
JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.jms.dsl
 
JmsMessageDrivenEndpoint - Class in org.springframework.integration.jms
A message-driven endpoint that receive JMS messages, converts them into Spring Integration Messages, and then sends the result to a channel.
JmsMessageDrivenEndpoint(AbstractMessageListenerContainer, ChannelPublishingJmsMessageListener) - Constructor for class org.springframework.integration.jms.JmsMessageDrivenEndpoint
Construct an instance with an externally configured container.
JmsMessageDrivenEndpointParser - Class in org.springframework.integration.jms.config
Parser for the <message-driven-channel-adapter> element and the <inbound-gateway> element of the 'jms' namespace.
JmsMessageDrivenEndpointParser(boolean) - Constructor for class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
JmsNamespaceHandler - Class in org.springframework.integration.jms.config
Namespace handler for Spring Integration's jms namespace.
JmsNamespaceHandler() - Constructor for class org.springframework.integration.jms.config.JmsNamespaceHandler
 
JmsOutboundChannelAdapterParser - Class in org.springframework.integration.jms.config
Parser for the <outbound-channel-adapter/> element of the jms namespace.
JmsOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.jms.config.JmsOutboundChannelAdapterParser
 
JmsOutboundChannelAdapterSpec<S extends JmsOutboundChannelAdapterSpec<S>> - Class in org.springframework.integration.jms.dsl
JmsOutboundChannelAdapterSpec(JmsTemplate) - Constructor for class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
 
JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware - Class in org.springframework.integration.jms.dsl
JmsOutboundChannelSpecTemplateAware(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
 
JmsOutboundGateway - Class in org.springframework.integration.jms
An outbound Messaging Gateway for request/reply JMS.
JmsOutboundGateway() - Constructor for class org.springframework.integration.jms.JmsOutboundGateway
 
JmsOutboundGateway.ReplyContainerProperties - Class in org.springframework.integration.jms
 
JmsOutboundGatewayParser - Class in org.springframework.integration.jms.config
Parser for the <outbound-gateway> element of the integration 'jms' namespace.
JmsOutboundGatewayParser() - Constructor for class org.springframework.integration.jms.config.JmsOutboundGatewayParser
 
JmsOutboundGatewaySpec - Class in org.springframework.integration.jms.dsl
JmsOutboundGatewaySpec(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
JmsOutboundGatewaySpec.ReplyContainerSpec - Class in org.springframework.integration.jms.dsl
An IntegrationComponentSpec for JmsOutboundGateway.ReplyContainerProperties.
JmsPollableMessageChannelSpec<S extends JmsPollableMessageChannelSpec<S,T>,T extends AbstractJmsChannel> - Class in org.springframework.integration.jms.dsl
JmsPollableMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
JmsPollableMessageChannelSpec(JmsChannelFactoryBean, ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
JmsPublishSubscribeMessageChannelSpec - Class in org.springframework.integration.jms.dsl
A JmsMessageChannelSpec for a SubscribableJmsChannel configured with a topic.
JmsPublishSubscribeMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
 
JmsSendingMessageHandler - Class in org.springframework.integration.jms
A MessageConsumer that sends the converted Message payload within a JMS Message.
JmsSendingMessageHandler(JmsTemplate) - Constructor for class org.springframework.integration.jms.JmsSendingMessageHandler
 
jmsTemplateSpec - Variable in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
 
jmsTemplateSpec - Variable in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
 
JmsTemplateSpec - Class in org.springframework.integration.jms.dsl
JmsTemplateSpec() - Constructor for class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
JmsTimeoutException - Exception in org.springframework.integration.jms
A timeout occurred within an async gateway.
JmsTimeoutException(String) - Constructor for exception org.springframework.integration.jms.JmsTimeoutException
 
JmxHeaders - Class in org.springframework.integration.jmx
Constants for JMX related Message Header keys.
JmxHeaders() - Constructor for class org.springframework.integration.jmx.JmxHeaders
 
JmxIntegrationConfigurationInitializer - Class in org.springframework.integration.jmx.config
The JMX Integration infrastructure beanFactory initializer.
JmxIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.jmx.config.JmxIntegrationConfigurationInitializer
 
JmxNamespaceHandler - Class in org.springframework.integration.jmx.config
Namespace handler for Spring Integration's jmx namespace.
JmxNamespaceHandler() - Constructor for class org.springframework.integration.jmx.config.JmxNamespaceHandler
 
Jpa - Class in org.springframework.integration.jpa.dsl
Factory class for JPA components.
JpaBaseOutboundEndpointSpec<S extends JpaBaseOutboundEndpointSpec<S>> - Class in org.springframework.integration.jpa.dsl
The base MessageHandlerSpec for JPA Outbound endpoints.
JpaBaseOutboundEndpointSpec(JpaExecutor) - Constructor for class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
 
JpaExecutor - Class in org.springframework.integration.jpa.core
Executes Jpa Operations that produce payload objects from the result of the provided: entityClass JpQl Select Query Sql Native Query JpQl Named Query Sql Native Named Query When objects are being retrieved, it also possibly to: delete the retrieved object If neither entityClass nor any other query is specified then the entity-class is "guessed" from the Message payload.idExpression
JpaExecutor(EntityManagerFactory) - Constructor for class org.springframework.integration.jpa.core.JpaExecutor
Constructor taking an EntityManagerFactory from which the EntityManager can be obtained.
JpaExecutor(EntityManager) - Constructor for class org.springframework.integration.jpa.core.JpaExecutor
Constructor taking an EntityManager directly.
JpaExecutor(JpaOperations) - Constructor for class org.springframework.integration.jpa.core.JpaExecutor
If custom behavior is required a custom implementation of JpaOperations can be passed in.
jpaExecutor - Variable in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
 
jpaExecutor - Variable in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
 
JpaInboundChannelAdapterParser - Class in org.springframework.integration.jpa.config.xml
The JPA Inbound Channel adapter parser
JpaInboundChannelAdapterParser() - Constructor for class org.springframework.integration.jpa.config.xml.JpaInboundChannelAdapterParser
 
JpaInboundChannelAdapterSpec - Class in org.springframework.integration.jpa.dsl
JpaInboundChannelAdapterSpec(JpaExecutor) - Constructor for class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
 
JpaNamespaceHandler - Class in org.springframework.integration.jpa.config.xml
The namespace handler for the JPA namespace
JpaNamespaceHandler() - Constructor for class org.springframework.integration.jpa.config.xml.JpaNamespaceHandler
 
JpaOperationFailedException - Exception in org.springframework.integration.jpa.core
An Exception that would be thrown if any of the Operations from JpaOperations fails
JpaOperationFailedException(String, String) - Constructor for exception org.springframework.integration.jpa.core.JpaOperationFailedException
 
JpaOperations - Interface in org.springframework.integration.jpa.core
The Interface containing all the JpaOperations those will be executed by the Jpa Spring Integration components.
JpaOutboundChannelAdapterParser - Class in org.springframework.integration.jpa.config.xml
The parser for JPA outbound channel adapter
JpaOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
 
JpaOutboundGateway - Class in org.springframework.integration.jpa.outbound
The Jpa Outbound Gateway will allow you to make outbound operations to either: submit (insert, delete) data to a database using JPA retrieve (select) data from a database Depending on the selected OutboundGatewayType, the outbound gateway will use either the JpaExecutor's poll method or its executeOutboundJpaOperation method.
JpaOutboundGateway(JpaExecutor) - Constructor for class org.springframework.integration.jpa.outbound.JpaOutboundGateway
Constructor taking an JpaExecutor that wraps all JPA Operations.
JpaOutboundGatewayFactoryBean - Class in org.springframework.integration.jpa.outbound
JpaOutboundGatewayFactoryBean() - Constructor for class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
JpaParameter - Class in org.springframework.integration.jpa.support
Abstraction of Jpa parameters allowing to provide static parameters and SpEl Expression based parameters.
JpaParameter() - Constructor for class org.springframework.integration.jpa.support.JpaParameter
Default constructor.
JpaParameter(String, Object, String) - Constructor for class org.springframework.integration.jpa.support.JpaParameter
Instantiates a new Jpa Parameter.
JpaParameter(Object, String) - Constructor for class org.springframework.integration.jpa.support.JpaParameter
Instantiates a new Jpa Parameter without a name.
JpaParserUtils - Class in org.springframework.integration.jpa.config.xml
Contains various utility methods for parsing JPA Adapter specific namespace elements and generation the respective BeanDefinitions.
JpaPollingChannelAdapter - Class in org.springframework.integration.jpa.inbound
Polling message source that produces messages from the result of the provided: entityClass JpQl Select Query Sql Native Query JpQl Named Query Sql Native Named Query After the objects have been polled, it also possibly to either: executes an update after the select possibly to updated the state of selected records executes an update (per retrieved object or for the entire payload) delete the retrieved object
JpaPollingChannelAdapter(JpaExecutor) - Constructor for class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
Constructor taking a JpaExecutor that provide all required JPA functionality.
jpaQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify a JPA query to perform persistent operation.
jpaQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a JPA query to perform persistent operation.
JpaRetrievingOutboundGatewaySpec - Class in org.springframework.integration.jpa.dsl
JpaRetrievingOutboundGatewaySpec(JpaExecutor) - Constructor for class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
 
JpaUpdatingOutboundEndpointSpec - Class in org.springframework.integration.jpa.dsl
A JpaBaseOutboundEndpointSpec extension for the updating JpaOutboundGateway mode.
JpaUpdatingOutboundEndpointSpec(JpaExecutor) - Constructor for class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
 
JpaUtils - Class in org.springframework.integration.jpa.support
This Utility contains a sub-set of utility methods from the Spring Data JPA Project.
JschProxyFactoryBean - Class in org.springframework.integration.sftp.session
Spring-friendly factory bean to create Jsch Proxy objects.
JschProxyFactoryBean(JschProxyFactoryBean.Type, String, int, String, String) - Constructor for class org.springframework.integration.sftp.session.JschProxyFactoryBean
 
JschProxyFactoryBean.Type - Enum in org.springframework.integration.sftp.session
 
JSON_CONTENT_TYPE - Static variable in class org.springframework.integration.json.ObjectToJsonTransformer
 
jsonAvailable() - Static method in class org.springframework.integration.support.json.JsonObjectMapperProvider
Returns true if a supported JSON implementation is on the class path.
JsonHeaders - Class in org.springframework.integration.mapping.support
Pre-defined names and prefixes to be used for setting and/or retrieving JSON entries from/to Message Headers and other adapter, e.g.
JsonInboundMessageMapper - Class in org.springframework.integration.support.json
InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.
JsonInboundMessageMapper(Class<?>, JsonInboundMessageMapper.JsonMessageParser<?>) - Constructor for class org.springframework.integration.support.json.JsonInboundMessageMapper
 
JsonInboundMessageMapper(Type, JsonInboundMessageMapper.JsonMessageParser<?>) - Constructor for class org.springframework.integration.support.json.JsonInboundMessageMapper
 
JsonInboundMessageMapper.JsonMessageParser<P> - Interface in org.springframework.integration.support.json
 
JsonObjectMapper<N,P> - Interface in org.springframework.integration.support.json
Strategy interface to convert an Object to/from the JSON representation.
JsonObjectMapperProvider - Class in org.springframework.integration.support.json
Simple factory to provide JsonObjectMapper instances based on jackson-databind lib in the classpath.
JsonOutboundMessageMapper - Class in org.springframework.integration.support.json
OutboundMessageMapper implementation the converts a Message to a JSON string representation.
JsonOutboundMessageMapper() - Constructor for class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
JsonOutboundMessageMapper(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
JsonPathUtils - Class in org.springframework.integration.json
JsonPropertyAccessor - Class in org.springframework.integration.json
A SpEL PropertyAccessor that knows how to read properties from JSON objects.
JsonPropertyAccessor() - Constructor for class org.springframework.integration.json.JsonPropertyAccessor
 
JsonPropertyAccessor.ArrayNodeAsList - Class in org.springframework.integration.json
An AbstractList implementation around ArrayNode with JsonPropertyAccessor.WrappedJsonNode aspect.
JsonPropertyAccessor.ToStringFriendlyJsonNode - Class in org.springframework.integration.json
A JsonPropertyAccessor.WrappedJsonNode implementation to represent JsonNode as string.
JsonPropertyAccessor.WrappedJsonNode<T extends com.fasterxml.jackson.databind.JsonNode> - Interface in org.springframework.integration.json
The base interface for wrapped JsonNode.
JsonToObjectTransformer - Class in org.springframework.integration.json
Transformer implementation that converts a JSON string payload into an instance of the provided target Class.
JsonToObjectTransformer() - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(ResolvableType) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
Construct an instance based on the provided ResolvableType.
JsonToObjectTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<?>, JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(ResolvableType, JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
Construct an instance based on the provided ResolvableType and JsonObjectMapper.
JsonToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
JsonToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 

K

Kafka - Class in org.springframework.integration.kafka.dsl
Factory class for Apache Kafka components.
KafkaAckCallback(KafkaMessageSource.KafkaAckInfo<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
Construct an instance with the provided properties.
KafkaAckCallbackFactory(ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
Construct an instance with the provided properties.
KafkaChannelParser - Class in org.springframework.integration.kafka.config.xml
Parser for a channel backed by a Kafka topic.
KafkaChannelParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaChannelParser
 
KafkaInboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
Parser for the inbound channel adapter.
KafkaInboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 
KafkaInboundChannelAdapterSpec<K,V> - Class in org.springframework.integration.kafka.dsl
Spec for a polled Kafka inbound channel adapter.
KafkaInboundGateway<K,V,R> - Class in org.springframework.integration.kafka.inbound
Inbound gateway.
KafkaInboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Construct an instance with the provided container.
KafkaInboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
Inbound gateway parser.
KafkaInboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
KafkaInboundGatewaySpec<K,V,R,S extends KafkaInboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
A MessagingGatewaySpec implementation for the KafkaInboundGateway.
KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
A ConcurrentMessageListenerContainer configuration KafkaInboundGatewaySpec extension.
KafkaIntegrationHeaders - Class in org.springframework.integration.kafka.support
Headers specifically for Spring Integration components.
KafkaMessageDrivenChannelAdapter<K,V> - Class in org.springframework.integration.kafka.inbound
Message-driven channel adapter.
KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Construct an instance with the provided mode.
KafkaMessageDrivenChannelAdapter.ListenerMode - Enum in org.springframework.integration.kafka.inbound
The listener mode for the container, record or batch.
KafkaMessageDrivenChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
Parser for the message driven channel adapter.
KafkaMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 
KafkaMessageDrivenChannelAdapterSpec<K,V,S extends KafkaMessageDrivenChannelAdapterSpec<K,V,S>> - Class in org.springframework.integration.kafka.dsl
KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A ConcurrentMessageListenerContainer configuration KafkaMessageDrivenChannelAdapterSpec extension.
KafkaMessageListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A helper class in the Builder pattern style to delegate options to the ConcurrentMessageListenerContainer.
KafkaMessageSource<K,V> - Class in org.springframework.integration.kafka.inbound
Polled message source for kafka.
KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
Construct an instance with the supplied parameters.
KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
Construct an instance with the supplied parameters.
KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
Construct an instance with the supplied parameters.
KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
Construct an instance with the supplied parameters.
KafkaMessageSource.KafkaAckCallback<K,V> - Class in org.springframework.integration.kafka.inbound
AcknowledgmentCallback for Kafka.
KafkaMessageSource.KafkaAckCallbackFactory<K,V> - Class in org.springframework.integration.kafka.inbound
AcknowledgmentCallbackFactory for KafkaAckInfo.
KafkaMessageSource.KafkaAckInfo<K,V> - Interface in org.springframework.integration.kafka.inbound
Information for building an KafkaAckCallback.
KafkaMessageSource.KafkaAckInfoImpl - Class in org.springframework.integration.kafka.inbound
Information for building an KafkaAckCallback.
KafkaNamespaceHandler - Class in org.springframework.integration.kafka.config.xml
The namespace handler for the Kafka namespace.
KafkaNamespaceHandler() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 
KafkaOutboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
Parser for the outbound channel adapter.
KafkaOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 
KafkaOutboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
Parser for the outbound gateway.
KafkaOutboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
KafkaOutboundGatewaySpec<K,V,R,S extends KafkaOutboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
A MessageHandlerSpec implementation for the KafkaProducerMessageHandler as a gateway.
KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
A KafkaTemplate-based KafkaProducerMessageHandlerSpec extension.
KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
An IntegrationComponentSpec implementation for the KafkaTemplate.
KafkaParsingUtils - Class in org.springframework.integration.kafka.config.xml
Utilities to assist with parsing XML.
KafkaPointToPointChannelSpec - Class in org.springframework.integration.kafka.dsl
Spec for a point to point channel backed by a Kafka topic.
KafkaPointToPointChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPointToPointChannelSpec
 
KafkaPollableChannelSpec - Class in org.springframework.integration.kafka.dsl
Spec for a pollable channel.
KafkaPollableChannelSpec(KafkaTemplate<?, ?>, KafkaMessageSource<?, ?>) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPollableChannelSpec
 
KafkaProducerMessageHandler<K,V> - Class in org.springframework.integration.kafka.outbound
Kafka Message Handler; when supplied with a ReplyingKafkaTemplate it is used as the handler in an outbound gateway.
KafkaProducerMessageHandler(KafkaTemplate<K, V>) - Constructor for class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
KafkaProducerMessageHandler.ProducerRecordCreator<K,V> - Interface in org.springframework.integration.kafka.outbound
Creates a ProducerRecord from a Message and/or properties derived from configuration and/or the message.
KafkaProducerMessageHandlerSpec<K,V,S extends KafkaProducerMessageHandlerSpec<K,V,S>> - Class in org.springframework.integration.kafka.dsl
KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A KafkaTemplate-based KafkaProducerMessageHandlerSpec extension.
KafkaPublishSubscribeChannelSpec - Class in org.springframework.integration.kafka.dsl
Spec for a publish/subscribe channel backed by a Kafka topic.
KafkaPublishSubscribeChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPublishSubscribeChannelSpec
 
KafkaSendFailureException - Exception in org.springframework.integration.kafka.support
An exception that is the payload of an ErrorMessage when a send fails.
KafkaSendFailureException(Message<?>, ProducerRecord<?, ?>, Throwable) - Constructor for exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
KafkaSubscribableChannelSpec<C extends SubscribableKafkaChannel> - Class in org.springframework.integration.kafka.dsl
Spec for a subscribable channel.
KafkaSubscribableChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.KafkaSubscribableChannelSpec
 
KafkaTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
An IntegrationComponentSpec implementation for the KafkaTemplate.
KEY - Static variable in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
KEY - Static variable in class org.springframework.integration.redis.metadata.RedisMetadataStore
 
KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
KEY_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
KeyDirectory(Object, String) - Constructor for class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
keySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
KOTLIN_FUNCTION_0_CLASS - Static variable in class org.springframework.integration.util.ClassUtils
The kotlin.jvm.functions.Function0 class object.
KOTLIN_FUNCTION_0_INVOKE_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The kotlin.jvm.functions.Function0#invoke method object.
KOTLIN_FUNCTION_1_CLASS - Static variable in class org.springframework.integration.util.ClassUtils
The kotlin.jvm.functions.Function1 class object.
KOTLIN_UNIT_CLASS - Static variable in class org.springframework.integration.util.ClassUtils
The kotlin.Unit class object.
KotlinScriptExecutor - Class in org.springframework.integration.scripting.jsr223
An AbstractScriptExecutor for the Kotlin scripts support.
KotlinScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.KotlinScriptExecutor
 
KRYO - Static variable in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
KryoClassListRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar used to validateRegistration a list of Java classes.
KryoClassListRegistrar(Class<?>...) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
KryoClassListRegistrar(List<Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
KryoClassMapRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar implementation backed by a Map used to explicitly set the registration ID for each class.
KryoClassMapRegistrar(Map<Integer, Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
 
KryoRegistrar - Interface in org.springframework.integration.codec.kryo
Strategy interface used by PojoCodec to configure registrations classes consistently across Kryo instances.
KryoRegistrationRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar implementation backed by a List of Registration.
KryoRegistrationRegistrar(List<Registration>) - Constructor for class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
 

L

label() - Method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
LambdaMessageProcessor - Class in org.springframework.integration.handler
The MessageProcessor implementation for method invocation on the single method classes - functional interface implementations.
LambdaMessageProcessor(Object, Class<?>) - Constructor for class org.springframework.integration.handler.LambdaMessageProcessor
 
lang(String) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
The script lang (Groovy, ruby, python etc.).
lang(String) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
The script lang (Groovy, ruby, python etc.).
LAST_MODIFIED_TIME - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
LAST_RELEASED_SEQUENCE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
lastFunction - Variable in class org.springframework.integration.test.mock.MockMessageHandler
 
lastIndexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
LastModifiedFileListFilter - Class in org.springframework.integration.file.filters
The FileListFilter implementation to filter those files which File.lastModified() is less than the LastModifiedFileListFilter.age in comparison with the current time.
LastModifiedFileListFilter() - Constructor for class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
LastModifiedFileListFilter(long) - Constructor for class org.springframework.integration.file.filters.LastModifiedFileListFilter
lazyConnect(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Set to false to attempt to connect during endpoint start.
LeaderEventPublisher - Interface in org.springframework.integration.leader.event
Interface for publishing leader based application events.
LeaderInitiator - Class in org.springframework.integration.zookeeper.leader
Bootstrap leadership candidates with ZooKeeper/Curator.
LeaderInitiator(CuratorFramework, Candidate) - Constructor for class org.springframework.integration.zookeeper.leader.LeaderInitiator
Construct a LeaderInitiator.
LeaderInitiator(CuratorFramework, Candidate, String) - Constructor for class org.springframework.integration.zookeeper.leader.LeaderInitiator
Construct a LeaderInitiator.
LeaderInitiator.LeaderListener - Class in org.springframework.integration.zookeeper.leader
Implementation of Curator leadership election listener.
LeaderInitiatorFactoryBean - Class in org.springframework.integration.zookeeper.config
Creates a LeaderInitiator.
LeaderInitiatorFactoryBean() - Constructor for class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
LeaderListener() - Constructor for class org.springframework.integration.zookeeper.leader.LeaderInitiator.LeaderListener
 
LeaderListenerParser - Class in org.springframework.integration.zookeeper.config.xml
 
LeaderListenerParser() - Constructor for class org.springframework.integration.zookeeper.config.xml.LeaderListenerParser
 
leaveOpen(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
lengthCheck(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
lengthCheck(boolean) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
lengthHeader(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
lengthHeader1() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
lengthHeader1(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
lengthHeader2() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
lengthHeader2(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
lengthHeader4() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
lengthHeader4(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
level() - Method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
LevelsContainer(Map<Class<?>, Level>, Map<String, Level>) - Constructor for class org.springframework.integration.test.util.TestUtils.LevelsContainer
 
lf() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
lf(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
lifecycleCondition - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
lifecycleLock - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
LINE_COUNT - Static variable in class org.springframework.integration.mail.MailHeaders
 
LinkNode - Class in org.springframework.integration.graph
Represents a link between nodes.
LinkNode(int, int, LinkNode.Type) - Constructor for class org.springframework.integration.graph.LinkNode
 
LinkNode.Type - Enum in org.springframework.integration.graph
 
list(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
List the files at the remote path.
list(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
list(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
list(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
list(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
list(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
LIST_MESSAGE_HANDLER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
listEligibleFiles(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Subclasses may refine the listing strategy by overriding this method.
ListenableMetadataStore - Interface in org.springframework.integration.metadata
ConcurrentMetadataStore with the ability of registering MetadataStoreListener callbacks, to be invoked when changes occur in the metadata store.
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
 
listFiles(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
listFiles(File) - Method in interface org.springframework.integration.file.DirectoryScanner
Scans the directory according to the strategy particular to this implementation and returns the selected files as a File array.
listFiles(File) - Method in class org.springframework.integration.file.RecursiveDirectoryScanner
 
listIterator() - Method in class org.springframework.integration.history.MessageHistory
 
listIterator(int) - Method in class org.springframework.integration.history.MessageHistory
 
listNames(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
listNames(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
listNames(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
listNames(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
loadBalancer(LoadBalancingStrategy) - Method in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
LoadBalancingChannelSpec<S extends MessageChannelSpec<S,C>,C extends AbstractMessageChannel> - Class in org.springframework.integration.dsl
 
LoadBalancingChannelSpec() - Constructor for class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
LoadBalancingStrategy - Interface in org.springframework.integration.dispatcher
Strategy for determining the iteration order of a MessageHandler list.
loadBalancingStrategy - Variable in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
loadCaptor(ApplicationContext) - Static method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
Deprecated.
since 5.2.9 in favor of @Import(MicrometerMetricsCaptorRegistrar.class); will be removed in 6.0.
LOCAL_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The local address (InetAddress) that the socket is connected to.
localAddress(String) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
localAddress(String) - Method in class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
 
localAddress(String) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
localDirectory(File) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure the local directory to copy files to.
localDirectory(File) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a directory path where remote files will be transferred to.
localDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a Function to evaluate directory path where remote files will be transferred to.
localDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression to evaluate directory path where remote files will be transferred to.
localDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression to evaluate directory path where remote files will be transferred to.
localFilename(Function<String, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a Function to be invoked to generate the local file name; argument passed to the apply method is the remote file name.
localFilenameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a SpEL expression to generate the local file name; the root object for the evaluation is the remote file name.
localFilenameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a SpEL expression to generate the local file name; the root object for the evaluation is the remote file name.
localFilenameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression for local files renaming after downloading.
localFilenameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression for local files renaming after downloading.
localFilenameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a Function for local files renaming after downloading.
localFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
A FileListFilter used to determine which files will generate messages after they have been synchronized.
locateComponentInHistory(List<Properties>, String, int) - Static method in class org.springframework.integration.test.util.TestUtils
 
LOCATION_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
 
lock(File) - Method in interface org.springframework.integration.file.FileLocker
Tries to lock the given file and returns true if it was successful, false otherwise.
lock(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
 
LOCK_REGISTRY_REGION - Static variable in class org.springframework.integration.gemfire.util.GemfireLockRegistry
 
locker(FileLocker) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Set a FileLocker to be used to guard files against duplicate processing.
lockRegistry(LockRegistry) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Used to obtain a Lock based on the groupId for concurrent operations on the MessageGroup.
LockRegistry - Interface in org.springframework.integration.support.locks
Strategy for maintaining a registry of shared locks
LockRegistryLeaderInitiator - Class in org.springframework.integration.support.leader
Component that initiates leader election based on holding a lock.
LockRegistryLeaderInitiator(LockRegistry) - Constructor for class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Create a new leader initiator with the provided lock registry and a default candidate (which just logs the leadership events).
LockRegistryLeaderInitiator(LockRegistry, Candidate) - Constructor for class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Create a new leader initiator.
LockRegistryLeaderInitiator.LeaderSelector - Class in org.springframework.integration.support.leader
 
LockRepository - Interface in org.springframework.integration.jdbc.lock
Encapsulation of the SQL shunting that is needed for locks.
log - Variable in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
log() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
log(LoggingHandler.Level) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for provided LoggingHandler.Level logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
log(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided logging category and INFO logging level.
log(LoggingHandler.Level, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level and logging category.
log(LoggingHandler.Level, String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
log(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
log(Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(LoggingHandler.Level, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(String, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO LoggingHandler.Level logging level, the provided logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(LoggingHandler.Level, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
log(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the provided logging category and Function for the log message.
log(LoggingHandler.Level, String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and Function for the log message.
log(LoggingHandler.Level, String, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
Log4j2LevelAdjuster - Class in org.springframework.integration.test.rule
A JUnit method Rule that changes the Log4J 2 logger level for a set of classes or packages while a test method is running.
logAndReply() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
logAndReply(LoggingHandler.Level) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for provided LoggingHandler.Level logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
logAndReply(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided logging category and INFO logging level.
logAndReply(LoggingHandler.Level, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level and logging category.
logAndReply(LoggingHandler.Level, String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
logAndReply(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
logAndReply(Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
logAndReply(LoggingHandler.Level, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
logAndReply(String, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO LoggingHandler.Level logging level, the provided logging category and SpEL expression to evaluate logger message at runtime against the request Message.
logAndReply(LoggingHandler.Level, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
logAndReply(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the provided logging category and Function for the log message.
logAndReply(LoggingHandler.Level, String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and Function for the log message.
logAndReply(LoggingHandler.Level, String, Expression) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a WireTap for the BaseIntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
logger - Variable in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
logger - Variable in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
logger - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.context.IntegrationObjectSupport
Logger that is available to subclasses
logger - Variable in class org.springframework.integration.core.ErrorMessagePublisher
 
logger - Variable in class org.springframework.integration.dispatcher.AbstractDispatcher
 
logger - Variable in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
logger - Variable in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
logger - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
logger - Variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
logger - Variable in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
logger - Variable in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
logger - Variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
logger - Variable in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
logger - Variable in class org.springframework.integration.mapping.AbstractHeaderMapper
 
logger - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
logger - Variable in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
logger - Variable in class org.springframework.integration.stomp.AbstractStompSessionManager
 
logger - Variable in class org.springframework.integration.store.AbstractMessageGroupStore
 
logger - Variable in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
 
LOGGER - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
logger - Variable in class org.springframework.integration.util.AbstractExpressionEvaluator
 
logger - Variable in class org.springframework.integration.util.SimplePool
 
logger - Variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
logger - Variable in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
LoggingChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the 'logging-channel-adapter' element.
LoggingChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.LoggingChannelAdapterParser
 
loggingConfigured - Variable in class org.springframework.integration.support.management.IntegrationManagement.ManagementOverrides
 
LoggingHandler - Class in org.springframework.integration.handler
MessageHandler implementation that simply logs the Message or its payload depending on the value of the 'shouldLogFullMessage' or SpEL 'logExpression' property.
LoggingHandler(String) - Constructor for class org.springframework.integration.handler.LoggingHandler
Create a LoggingHandler with the given log level (case-insensitive).
LoggingHandler(LoggingHandler.Level) - Constructor for class org.springframework.integration.handler.LoggingHandler
Create a LoggingHandler with the given log LoggingHandler.Level.
LoggingHandler.Level - Enum in org.springframework.integration.handler
 
LOGIN - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
LogLevels - Annotation Type in org.springframework.integration.test.condition
Test classes annotated with this will change logging levels between tests.
LogLevelsCondition - Class in org.springframework.integration.test.condition
JUnit condition that adjusts and reverts log levels before/after each test.
LogLevelsCondition() - Constructor for class org.springframework.integration.test.condition.LogLevelsCondition
 
longExpression(String) - Static method in class org.springframework.integration.expression.ExpressionUtils
Return a ValueExpression for a simple literal, otherwise a SpelExpression.
LongRunningIntegrationTest - Class in org.springframework.integration.test.support
Rule to prevent long running tests from running on every build; set environment variable RUN_LONG_INTEGRATION_TESTS on a CI nightly build to ensure coverage.
LongRunningIntegrationTest() - Constructor for class org.springframework.integration.test.support.LongRunningIntegrationTest
 
LongRunningTest - Annotation Type in org.springframework.integration.test.condition
JUnit Jupiter condition to prevent long running tests from running on every build; set environment variable RUN_LONG_INTEGRATION_TESTS on a CI nightly build to ensure coverage.
LOOKUP_HOST - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
lookupHost(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
lookupHost(boolean) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
lookupKeyQualifier(String) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Set a qualifier that will prefix the connection factory lookup key; default none.
ls(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
List remote files to local representation.
ls(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 

M

Mail - Class in org.springframework.integration.mail.dsl
The factory for Spring Integration Mail components.
mailHandler(Socket) - Method in class org.springframework.integration.test.mail.TestMailServer.ImapServer
 
mailHandler(Socket) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
mailHandler(Socket) - Method in class org.springframework.integration.test.mail.TestMailServer.Pop3Server
 
mailHandler(Socket) - Method in class org.springframework.integration.test.mail.TestMailServer.SmtpServer
 
MailHeaderEnricherParser - Class in org.springframework.integration.mail.config
 
MailHeaderEnricherParser() - Constructor for class org.springframework.integration.mail.config.MailHeaderEnricherParser
 
MailHeaders - Class in org.springframework.integration.mail
Pre-defined header names to be used for setting and/or retrieving Mail Message attributes from/to integration Message Headers.
MailHeadersBuilder - Class in org.springframework.integration.mail.dsl
The Mail specific MapBuilder implementation.
MailInboundChannelAdapterParser - Class in org.springframework.integration.mail.config
Parser for the <inbound-channel-adapter> element of Spring Integration's 'mail' namespace.
MailInboundChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.MailInboundChannelAdapterParser
 
MailInboundChannelAdapterSpec<S extends MailInboundChannelAdapterSpec<S,R>,R extends AbstractMailReceiver> - Class in org.springframework.integration.mail.dsl
MailInboundChannelAdapterSpec(R) - Constructor for class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
MailInboundChannelAdapterSpec(R, boolean) - Constructor for class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
MailIntegrationEvent - Class in org.springframework.integration.mail.event
 
MailIntegrationEvent(Object) - Constructor for class org.springframework.integration.mail.event.MailIntegrationEvent
 
MailIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.mail.event.MailIntegrationEvent
 
MailNamespaceHandler - Class in org.springframework.integration.mail.config
Namespace handler for the 'mail' namespace.
MailNamespaceHandler() - Constructor for class org.springframework.integration.mail.config.MailNamespaceHandler
 
MailOutboundChannelAdapterParser - Class in org.springframework.integration.mail.config
Parser for the <outbound-channel-adapter/> element of the 'mail' namespace.
MailOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.MailOutboundChannelAdapterParser
 
MailReceiver - Interface in org.springframework.integration.mail
Strategy interface for receiving mail Messages.
MailReceiverFactoryBean - Class in org.springframework.integration.mail.config
 
MailReceiverFactoryBean() - Constructor for class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
MailReceivingMessageSource - Class in org.springframework.integration.mail
MessageSource implementation that delegates to a MailReceiver to poll a mailbox.
MailReceivingMessageSource(MailReceiver) - Constructor for class org.springframework.integration.mail.MailReceivingMessageSource
 
MailSendingMessageHandler - Class in org.springframework.integration.mail
A MessageHandler implementation for sending mail.
MailSendingMessageHandler(MailSender) - Constructor for class org.springframework.integration.mail.MailSendingMessageHandler
Create a MailSendingMessageHandler.
MailSendingMessageHandlerSpec - Class in org.springframework.integration.mail.dsl
 
MailSendingMessageHandlerSpec(String) - Constructor for class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
 
MailToStringTransformer - Class in org.springframework.integration.mail.transformer
Transforms a Message payload of type Message to a String.
MailToStringTransformer() - Constructor for class org.springframework.integration.mail.transformer.MailToStringTransformer
 
MailToStringTransformerParser - Class in org.springframework.integration.mail.config
Parser for the <mail-to-string-transformer> element.
MailToStringTransformerParser() - Constructor for class org.springframework.integration.mail.config.MailToStringTransformerParser
 
MailTransportUtils - Class in org.springframework.integration.mail
Collection of utility methods to work with Mail transports.
MailTransportUtils() - Constructor for class org.springframework.integration.mail.MailTransportUtils
 
MailUtils - Class in org.springframework.integration.mail.support
Utilities for handling mail messages.
makeDirectories(String, Session<F>, String, Log) - Static method in class org.springframework.integration.file.remote.RemoteFileUtils
Recursively create remote directories.
ManageableLifecycle - Interface in org.springframework.integration.support.management
Makes Lifecycle methods manageable.
ManageableSmartLifecycle - Interface in org.springframework.integration.support.management
Extend ManageableLifecycle to make those methods manageable.
ManagedEndpoint - Class in org.springframework.integration.monitor
Deprecated.
this is no longer used by the framework. Replaced by ManageableLifecycle.
ManagedEndpoint(AbstractEndpoint) - Constructor for class org.springframework.integration.monitor.ManagedEndpoint
Deprecated.
 
MANAGEMENT_CONFIGURER_NAME - Static variable in class org.springframework.integration.config.IntegrationManagementConfigurer
Bean name of the configurer.
managementConfigurer(ObjectProvider<MetricsCaptor>) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
ManagementOverrides() - Constructor for class org.springframework.integration.support.management.IntegrationManagement.ManagementOverrides
 
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
 
MAP_KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
MapArgumentResolver - Class in org.springframework.integration.handler.support
A HandlerMethodArgumentResolver implementation to resolve argument for the MethodParameter as a Map or Properties.
MapArgumentResolver() - Constructor for class org.springframework.integration.handler.support.MapArgumentResolver
 
MapBuilder<B extends MapBuilder<B,K,V>,K,V> - Class in org.springframework.integration.support
A Builder pattern implementation for the Map.
MapBuilder() - Constructor for class org.springframework.integration.support.MapBuilder
 
MapContentMatchers<T,V> - Class in org.springframework.integration.test.matcher
Matchers that examine the contents of a Map.
mapHeaders(Message<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
MapJsonSerializer - Class in org.springframework.integration.ip.tcp.serializer
Serializes a Map as JSON.
MapJsonSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
 
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.
MapMessageConverter - Class in org.springframework.integration.support.converter
Converts to/from a Map with 2 keys ('headers' and 'payload').
MapMessageConverter() - Constructor for class org.springframework.integration.support.converter.MapMessageConverter
 
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.http.dsl.BaseHttpMessageHandlerSpec
Provide the pattern array for request headers to map.
mappedRequestHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Provide the pattern array for request headers to map.
mappedResponseHeaders(String...) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Provide the pattern array for response headers to map.
mappedResponseHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Provide the pattern array for response headers to map.
mapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.dsl.GatewayProxySpec
An MethodArgsMessageMapper to map the method arguments to a Message.
MAPPER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
mapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
MappingMessageRouterManagement - Interface in org.springframework.integration.support.management
Exposes channel mapping operations when the router is proxied.
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.
mapRow(ResultSet, int) - Method in class org.springframework.integration.jdbc.store.channel.MessageRowMapper
 
MapToObjectTransformer - Class in org.springframework.integration.transformer
Will transform Map to an instance of Object.
MapToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformer(String) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
MapToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
mark() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
MARKER - Static variable in class org.springframework.integration.file.FileHeaders
Record is a file marker (START/END)
markers() - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
Specify if FileSplitter should emit FileSplitter.FileMarkers Defaults to false.
markers(boolean) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
Specify if FileSplitter should emit FileSplitter.FileMarkers and if they should be converted to the JSON string representation.
marshaller(Marshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
Specify a marshaller to use.
marshaller(Marshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Configure the marshaller to use.
marshallingInboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance.
marshallingInboundGateway(Marshaller) - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance with the provided Marshaller (which must also implement Unmarshaller).
marshallingOutboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance with a default WebServiceTemplate.
marshallingOutboundGateway(WebServiceTemplate) - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance with the provided WebServiceTemplate.
MarshallingTransformer - Class in org.springframework.integration.xml.transformer
An implementation of AbstractTransformer that delegates to an OXM Marshaller.
MarshallingTransformer(Marshaller, ResultTransformer) - Constructor for class org.springframework.integration.xml.transformer.MarshallingTransformer
 
MarshallingTransformer(Marshaller) - Constructor for class org.springframework.integration.xml.transformer.MarshallingTransformer
 
MarshallingTransformerParser - Class in org.springframework.integration.xml.config
 
MarshallingTransformerParser() - Constructor for class org.springframework.integration.xml.config.MarshallingTransformerParser
 
MarshallingWebServiceInboundGateway - Class in org.springframework.integration.ws
 
MarshallingWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
Creates a new MarshallingWebServiceInboundGateway.
MarshallingWebServiceInboundGateway(Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
Creates a new MarshallingWebServiceInboundGateway with the given marshaller.
MarshallingWebServiceInboundGateway(Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
Creates a new MarshallingWebServiceInboundGateway with the given marshaller and unmarshaller.
MarshallingWebServiceOutboundGateway - Class in org.springframework.integration.ws
An outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.
MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, Unmarshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(String, Marshaller, Unmarshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(String, Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(String, Marshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(String, Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
MarshallingWebServiceOutboundGateway(String, WebServiceTemplate) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
Construct an instance based on the provided Web Service URI and WebServiceTemplate.
MarshallingWebServiceOutboundGateway(DestinationProvider, WebServiceTemplate) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
Construct an instance based on the provided DestinationProvider and WebServiceTemplate.
MarshallingWsInboundGatewaySpec - Class in org.springframework.integration.ws.dsl
MarshallingWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
 
MarshallingWsOutboundGatewayNoTemplateSpec() - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
MarshallingWsOutboundGatewaySpec - Class in org.springframework.integration.ws.dsl
MarshallingWsOutboundGatewaySpec(WebServiceTemplate) - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec
 
MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec - Class in org.springframework.integration.ws.dsl
Spec for a MarshallingWebServiceOutboundGateway where an external WebServiceTemplate is not provided.
matches(Object, Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
matches(Object) - Method in class org.springframework.integration.test.matcher.MessageMatcher
 
matches(Object) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
matches(Method) - Method in class org.springframework.integration.util.UniqueMethodFilter
 
matchesSafely(Message<T>) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
 
matchesSafely(Map<? super T, ? super V>) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
 
matchesSafely(Message<?>) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.CompositeHeaderMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
 
matchHeader(String) - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
Specify if the given headerName matches.
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
MAX_MESSAGES_UNBOUNDED - Static variable in class org.springframework.integration.scheduling.PollerMetadata
 
maxAge(long) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
The maximum age (in seconds) of the cache duration for pre-flight responses.
maxAttempts(int) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Set the maximum number of release attempts for when message release fails.
maxConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
maxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The max for concurrent consumers number to use.
maxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
maxFetchSize(int) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Specify the maximum number of remote files that will be fetched on each fetch attempt.
maxFetchSize(int) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Specify the maximum number of remote files that will be fetched on each fetch attempt.
maxFetchSize(int) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
maxFetchSize(int) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
The maximum for fetch size.
maxMessagesPerPoll(long) - Method in class org.springframework.integration.dsl.PollerSpec
 
maxMessagesPerTask(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
The max messages per task.
maxMessagesPerTask(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
maxMessagesPerTask(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
maxResults(int) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Set the maximum number of results expression.
maxResults(int) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Set the maximum number of results expression.
maxResultsExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a SpEL expression for maximum number of results expression.
maxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a SpEL expression for maximum number of results expression.
maxResultsExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression for maximum number of results expression.
maxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
Specify a SpEL expression for maximum number of results expression.
maxSubscribers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
maxSubscribers - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
maxSubscribers - Variable in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.LoadBalancingChannelSpec
 
maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
maxSubscribers(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
MBEAN_EXPORTER_NAME - Static variable in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
A name for default IntegrationMBeanExporter bean.
MBeanAttributeFilter - Interface in org.springframework.integration.jmx
 
mbeanExporter() - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
 
MBeanExporterParser - Class in org.springframework.integration.jmx.config
Parser for the 'mbean-export' element of the integration JMX namespace.
MBeanExporterParser() - Constructor for class org.springframework.integration.jmx.config.MBeanExporterParser
 
MBeanObjectConverter - Interface in org.springframework.integration.jmx
 
MBeanTreePollingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
MBeanTreePollingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
 
MBeanTreePollingMessageSource - Class in org.springframework.integration.jmx
A MessageSource implementation that retrieves a snapshot of a filtered subset of the MBean tree.
MBeanTreePollingMessageSource(MBeanObjectConverter) - Constructor for class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
merge(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
merge(Object, int, boolean) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
merge(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
The entity to be merged with the EntityManager.
merge(Object, int, boolean) - Method in interface org.springframework.integration.jpa.core.JpaOperations
The entity to be merged with the EntityManager.
MERGED_INTEGRATION_GLOBAL_PROPERTIES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
mergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
Flag which determines if the default converters should be available after custom converters.
MESSAGE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
MESSAGE - Static variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
MESSAGE - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
MESSAGE_FORMAT_ERROR - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
MESSAGE_GROUP_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MESSAGE_HANDLER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
MESSAGE_ID - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
MESSAGE_ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
MESSAGE_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MESSAGE_PUBLISHING_ERROR_HANDLER_BEAN_NAME - Static variable in class org.springframework.integration.channel.ChannelUtils
 
MESSAGE_SOURCE - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
MESSAGE_SOURCE - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
 
messageArgumentCaptor() - Static method in class org.springframework.integration.test.mock.MockIntegration
 
messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
MessageBuilder<T> - Class in org.springframework.integration.support
The default message builder; creates immutable GenericMessages.
MessageBuilderFactory - Interface in org.springframework.integration.support
 
messageBuilderForReply(Object) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
MessageChannelNode - Class in org.springframework.integration.graph
Represents a message channel.
MessageChannelNode(int, String, MessageChannel) - Constructor for class org.springframework.integration.graph.MessageChannelNode
 
MessageChannelReactiveUtils - Class in org.springframework.integration.channel
Deprecated.
since 5.3 in favor of IntegrationReactiveUtils.
MessageChannelReference - Class in org.springframework.integration.dsl.support
An "artificial" MessageChannel implementation which will be unwrapped to the MessageChannel bean on the bean registration phase.
MessageChannelReference(String) - Constructor for class org.springframework.integration.dsl.support.MessageChannelReference
 
MessageChannels - Class in org.springframework.integration.dsl
 
MessageChannelSpec<S extends MessageChannelSpec<S,C>,C extends AbstractMessageChannel> - Class in org.springframework.integration.dsl
 
MessageChannelSpec() - Constructor for class org.springframework.integration.dsl.MessageChannelSpec
 
messageChannelToFlux(MessageChannel) - Static method in class org.springframework.integration.util.IntegrationReactiveUtils
Adapt a provided MessageChannel into a Flux source: - a FluxMessageChannel is returned as is because it is already a Publisher; - a SubscribableChannel is subscribed with a MessageHandler for the Sinks.Many#tryEmitNext(Object) which is returned from this method; - a PollableChannel is wrapped into a MessageSource lambda and reuses IntegrationReactiveUtils.messageSourceToFlux(MessageSource).
MessageCodec - Class in org.springframework.integration.codec.kryo
PojoCodec configured to encode/decode Message<?>s.
MessageCodec() - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
Construct an instance using the default registration ids for message headers.
MessageCodec(MessageKryoRegistrar) - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
Construct an instance using a custom registrar - usually used if different registration ids are required for message headers.
MessageCollectionCallback<T> - Interface in org.springframework.integration.mongodb.outbound
The callback to be used with the MongoDbOutboundGateway as an alternative to other query options on the gateway.
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
 
messageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
Set the message converter to replace the default.
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Set the message converter to use with a record-based consumer.
messageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
Set the message converter to use.
MessageConverter - Interface in org.springframework.integration.syslog
A converter to convert the raw message created by the underlying UDP/TCP endpoint to a specific form of Syslog message.
messageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Provide a MessageConverter (as an alternative to ZeroMqMessageHandlerSpec.messageMapper(org.springframework.integration.mapping.OutboundMessageMapper<byte[]>)) for converting a request message into byte[] for sending into ZeroMq socket.
messageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Provide a MessageConverter (as an alternative to ZeroMqMessageProducerSpec.messageMapper(org.springframework.integration.mapping.InboundMessageMapper<byte[]>)) for converting a consumed data into a message to produce.
messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
Set the message body converters to use.
messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
Set a list of HttpMessageConverters to be used by the underlying RestTemplate.
MessageConvertingTcpMessageMapper - Class in org.springframework.integration.ip.tcp.connection
 
MessageConvertingTcpMessageMapper(MessageConverter) - Constructor for class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
 
MessageCountReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that releases only the first n messages, where n is a threshold.
MessageCountReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
Convenient constructor is only one message is required (threshold=1).
MessageCountReleaseStrategy(int) - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
Construct an instance based on the provided threshold.
MessageDecorator - Interface in org.springframework.integration.support
The Message decoration contract.
MessageDispatcher - Interface in org.springframework.integration.dispatcher
Strategy interface for dispatching messages to handlers.
MessageDispatchingException - Exception in org.springframework.integration
Exception that indicates an internal error occurred within a MessageDispatcher preventing message delivery.
MessageDispatchingException(String) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDocument - Class in org.springframework.integration.mongodb.store
The entity class to wrap Message to the MongoDB document.
MessageDocument(Message<?>) - Constructor for class org.springframework.integration.mongodb.store.MessageDocument
 
MessageDocumentFields - Class in org.springframework.integration.mongodb.store
 
messageDrivenChannelAdapter(JmsListenerContainerSpec<?, ? extends AbstractMessageListenerContainer>) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
MessageEndpoint - Annotation Type in org.springframework.integration.annotation
Stereotype annotation indicating that a class is capable of serving as a Message Endpoint.
messageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Specify the WebServiceMessageFactory to use.
messageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify the WebServiceMessageFactory to use.
MessageFilter - Class in org.springframework.integration.filter
Message Handler that delegates to a MessageSelector.
MessageFilter(MessageSelector) - Constructor for class org.springframework.integration.filter.MessageFilter
Create a MessageFilter that will delegate to the given MessageSelector.
messageFunctions - Variable in class org.springframework.integration.test.mock.MockMessageHandler
 
MessageGatewayNode - Class in org.springframework.integration.graph
Represents an inbound gateway.
MessageGatewayNode(int, String, MessagingGatewaySupport, String, String) - Constructor for class org.springframework.integration.graph.MessageGatewayNode
 
MessageGroup - Interface in org.springframework.integration.store
A group of messages that are correlated with each other and should be processed in the same context.
MessageGroupExpiredEvent - Class in org.springframework.integration.aggregator
Event representing the expiration of a message group.
MessageGroupExpiredEvent(Object, Object, int, Date, Date, boolean) - Constructor for class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
MessageGroupFactory - Interface in org.springframework.integration.store
The MessageGroup factory strategy.
MessageGroupMetadata - Class in org.springframework.integration.store
Value Object holding metadata about a MessageGroup in the MessageGroupStore.
MessageGroupMetadata(MessageGroup) - Constructor for class org.springframework.integration.store.MessageGroupMetadata
 
MessageGroupProcessor - Interface in org.springframework.integration.aggregator
A processor for correlated groups of messages.
MessageGroupQueue - Class in org.springframework.integration.store
A BlockingQueue that is backed by a MessageGroupStore.
MessageGroupQueue(BasicMessageGroupStore, Object) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, int) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, int, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
messageGroupSize(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Returns the number of messages persisted for the specified channel id (groupId) and the specified region (JdbcChannelMessageStore.setRegion(String)).
messageGroupSize(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
messageGroupSize(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Returns the size of this MessageGroup.
messageGroupSize(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
MessageGroupStore - Interface in org.springframework.integration.store
Defines additional storage operations on groups of messages linked by a group id.
MessageGroupStore.MessageGroupCallback - Interface in org.springframework.integration.store
Invoked when a MessageGroupStore expires a group.
MessageGroupStoreReaper - Class in org.springframework.integration.store
Convenient configurable component to allow explicit timed expiry of MessageGroup instances in a MessageGroupStore.
MessageGroupStoreReaper(MessageGroupStore) - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
 
MessageGroupStoreReaper() - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
 
messageHandlerAttributes - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
MessageHandlerChain - Class in org.springframework.integration.handler
A composite MessageHandler implementation that invokes a chain of MessageHandler instances in order.
MessageHandlerChain() - Constructor for class org.springframework.integration.handler.MessageHandlerChain
 
MessageHandlerNode - Class in org.springframework.integration.graph
Represents a message handler.
MessageHandlerNode(int, String, MessageHandler, String, String) - Constructor for class org.springframework.integration.graph.MessageHandlerNode
 
MessageHandlerSpec<S extends MessageHandlerSpec<S,H>,H extends MessageHandler> - Class in org.springframework.integration.dsl
MessageHandlerSpec() - Constructor for class org.springframework.integration.dsl.MessageHandlerSpec
 
MessageHandlerSupport - Class in org.springframework.integration.handler
Base class for Message handling components that provides basic validation and error handling capabilities.
MessageHandlerSupport() - Constructor for class org.springframework.integration.handler.MessageHandlerSupport
 
MessageHandlingExpressionEvaluatingAdviceException(Message<?>, String, Throwable, Object) - Constructor for exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
 
MessageHandlingTask(MessageHandlingRunnable) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
 
MessageHandlingTaskDecorator - Interface in org.springframework.integration.dispatcher
The strategy to decorate MessageHandlingRunnable tasks to be used with the Executor.
messageHeaders(Map<String, Expression>) - Method in class org.springframework.integration.dsl.MessageSourceSpec
Expressions with which to enhance headers.
MessageHeadersJacksonSerializer - Class in org.springframework.integration.support.json
A Jackson StdSerializer implementation to serialize MessageHeaders as a HashMap.
MessageHeadersJacksonSerializer() - Constructor for class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
MessageHistory - Class in org.springframework.integration.history
 
MessageHistory.Entry - Class in org.springframework.integration.history
Inner class for each Entry in the history.
MessageHistoryConfigurer - Class in org.springframework.integration.history
 
MessageHistoryConfigurer() - Constructor for class org.springframework.integration.history.MessageHistoryConfigurer
 
MessageHistoryParser - Class in org.springframework.integration.config.xml
The <message-history/> parser.
MessageHistoryParser() - Constructor for class org.springframework.integration.config.xml.MessageHistoryParser
 
MessageHistoryRegistrar - Class in org.springframework.integration.config
MessageHistoryRegistrar() - Constructor for class org.springframework.integration.config.MessageHistoryRegistrar
 
MessageHolder - Class in org.springframework.integration.store
The MessageStore specific value object to keep the Message and its metadata.
MessageHolder(Message<?>) - Constructor for class org.springframework.integration.store.MessageHolder
 
messageIdEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
messageIdIterator() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
MessageJacksonDeserializer<T extends Message<?>> - Class in org.springframework.integration.support.json
A Jackson StdNodeBasedDeserializer extension for Message implementations.
MessageJacksonDeserializer(Class<T>) - Constructor for class org.springframework.integration.support.json.MessageJacksonDeserializer
 
messageKey(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure the message key to store message in Kafka topic.
messageKey(Function<Message<P>, ?>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at runtime to determine the message key under which a message will be stored in the topic.
messageKeyExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
messageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
MessageKryoRegistrar - Class in org.springframework.integration.codec.kryo
Registers common MessageHeader types and Serializers.
MessageKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
MessageListProcessor - Interface in org.springframework.integration.aggregator
 
messageMapper(BytesMessageMapper) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
Provide a BytesMessageMapper to convert to/from messages when send or receive happens on the sockets.
messageMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Provide an OutboundMessageMapper to convert a request message into byte[] for sending into ZeroMq socket.
messageMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Provide an InboundMessageMapper to convert a consumed data into a message to produce.
MessageMappingException - Exception in org.springframework.integration.mapping
Exception that indicates an error during message mapping.
MessageMappingException(String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(Message<?>, String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMatcher - Class in org.springframework.integration.test.matcher
Matcher to make assertions about message equality easier.
MessageMatcher(Message<?>) - Constructor for class org.springframework.integration.test.matcher.MessageMatcher
 
MessageMetadata - Class in org.springframework.integration.store
Value Object holding metadata about a Message in the MessageStore.
MessageMetadata(UUID) - Constructor for class org.springframework.integration.store.MessageMetadata
 
MessagePredicate - Class in org.springframework.integration.test.predicate
Predicate to make assertions about message equality easier.
MessagePredicate(Message<?>, String...) - Constructor for class org.springframework.integration.test.predicate.MessagePredicate
 
MessagePreparedStatementSetter - Interface in org.springframework.integration.jdbc
The callback to be used with the JdbcMessageHandler as an alternative to the SqlParameterSourceFactory.
MessageProcessingHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
 
MessageProcessingHeaderValueMessageProcessor(MessageProcessor<T>) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
MessageProcessingHeaderValueMessageProcessor(Object) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
MessageProcessingHeaderValueMessageProcessor(Object, String) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
messageProcessor(MessageProcessor<?>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an optional custom MessageProcessor for the enricher.
messageProcessor(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an ExpressionEvaluatingMessageProcessor that evaluates to a Map of additional headers.
messageProcessor(String, String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an MethodInvokingMessageProcessor that invokes the method on the bean - the method must return a Map of headers.
MessageProcessor<T> - Interface in org.springframework.integration.handler
This defines the lowest-level strategy of processing a Message and returning some Object (or null).
MessageProcessorMessageSource - Class in org.springframework.integration.endpoint
The MessageSource strategy implementation to produce a Message from underlying MessageProcessorMessageSource.messageProcessor for polling endpoints.
MessageProcessorMessageSource(MessageProcessor<?>) - Constructor for class org.springframework.integration.endpoint.MessageProcessorMessageSource
 
MessageProcessorSpec<S extends MessageProcessorSpec<S>> - Class in org.springframework.integration.dsl
The IntegrationComponentSpec specific base class for MessageProcessors.
MessageProcessorSpec() - Constructor for class org.springframework.integration.dsl.MessageProcessorSpec
 
MessageProducer - Interface in org.springframework.integration.core
Base interface for any component that is capable of sending messages to a MessageChannel.
MessageProducerNode - Class in org.springframework.integration.graph
Represents an inbound message producer.
MessageProducerNode(int, String, MessageProducerSupport, String, String) - Constructor for class org.springframework.integration.graph.MessageProducerNode
 
MessageProducerSpec<S extends MessageProducerSpec<S,P>,P extends MessageProducerSupport> - Class in org.springframework.integration.dsl
MessageProducerSpec(P) - Constructor for class org.springframework.integration.dsl.MessageProducerSpec
 
MessageProducerSupport - Class in org.springframework.integration.endpoint
A support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.
MessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.MessageProducerSupport
 
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).
MessagePublishingErrorHandler - Class in org.springframework.integration.channel
ErrorHandler implementation that sends an ErrorMessage to a MessageChannel.
MessagePublishingErrorHandler() - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
 
MessagePublishingErrorHandler(DestinationResolver<MessageChannel>) - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
 
MessagePublishingInterceptor - Class in org.springframework.integration.aop
A MethodInterceptor that publishes Messages to a channel.
MessagePublishingInterceptor(PublisherMetadataSource) - Constructor for class org.springframework.integration.aop.MessagePublishingInterceptor
 
MessageRejectedException - Exception in org.springframework.integration
Exception that indicates a message has been rejected by a selector.
MessageRejectedException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRejectedException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRouter - Interface in org.springframework.integration.router
Routers implementing this interface have a default output channel.
MessageRowMapper - Class in org.springframework.integration.jdbc.store.channel
Convenience class to be used to unpack a Message from a result set row.
MessageRowMapper(AllowListDeserializingConverter, LobHandler) - Constructor for class org.springframework.integration.jdbc.store.channel.MessageRowMapper
 
messages - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
MessageSelectingInterceptor - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that delegates to a list of MessageSelectors to decide whether a Message should be accepted on the MessageChannel.
MessageSelectingInterceptor(MessageSelector...) - Constructor for class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
MessageSelector - Interface in org.springframework.integration.core
Strategy interface for message selection.
messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
 
messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Configure a message selector in the DefaultMessageListenerContainer (when message driven) or the JmsTemplate (when polled).
MessageSelectorChain - Class in org.springframework.integration.selector
A message selector implementation that passes incoming messages through a chain of selectors.
MessageSelectorChain() - Constructor for class org.springframework.integration.selector.MessageSelectorChain
 
MessageSelectorChain.VotingStrategy - Enum in org.springframework.integration.selector
 
messageSenders - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
messageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Specify the WebServiceMessageSenders to use.
messageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify the WebServiceMessageSenders to use.
MessageSequenceComparator - Class in org.springframework.integration.aggregator
 
MessageSequenceComparator() - Constructor for class org.springframework.integration.aggregator.MessageSequenceComparator
 
MessageSessionCallback<F,T> - Interface in org.springframework.integration.file.remote
Callback invoked by RemoteFileOperations.executeForMessage() - allows multiple operations on a session.
MessageSource<T> - Interface in org.springframework.integration.core
Base interface for any source of Messages that can be polled.
messageSource(Resource) - Static method in class org.springframework.integration.scripting.dsl.Scripts
Factory for the ScriptMessageSourceSpec based on the Resource.
messageSource(String) - Static method in class org.springframework.integration.scripting.dsl.Scripts
Factory for the ScriptMessageSourceSpec based on the script location.
MessageSourceManagement - Interface in org.springframework.integration.support.management
Message sources implementing this interface have additional properties that can be set or examined using JMX.
MessageSourceMutator - Interface in org.springframework.integration.aop
A ReceiveMessageAdvice extension that can mutate a MessageSource before and/or after MessageSource.receive() is called.
MessageSourceNode - Class in org.springframework.integration.graph
Represents a message source.
MessageSourceNode(int, String, MessageSource<?>, String, String) - Constructor for class org.springframework.integration.graph.MessageSourceNode
 
MessageSourcePollingTemplate - Class in org.springframework.integration.endpoint
A PollingOperations used to ad-hoc poll a MessageSource.
MessageSourcePollingTemplate(MessageSource<?>) - Constructor for class org.springframework.integration.endpoint.MessageSourcePollingTemplate
 
MessageSourceSpec<S extends MessageSourceSpec<S,H>,H extends MessageSource<?>> - Class in org.springframework.integration.dsl
MessageSourceSpec() - Constructor for class org.springframework.integration.dsl.MessageSourceSpec
 
messageSourceToFlux(MessageSource<T>) - Static method in class org.springframework.integration.util.IntegrationReactiveUtils
Wrap a provided MessageSource into a Flux for pulling the on demand.
messagesPerAck(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
 
messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
messageStore(PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
 
MessageStore - Interface in org.springframework.integration.store
Strategy interface for storing and retrieving messages.
MessageStoreException - Exception in org.springframework.integration.store
Exception for problems that occur when using a MessageStore implementation.
MessageStoreException(Message<?>) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(String) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, String) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreSpec(ChannelMessageStore, Object) - Constructor for class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
 
MessageTimeoutException - Exception in org.springframework.integration
Exception that indicates a timeout elapsed prior to successful message delivery.
MessageTimeoutException(String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
messageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
MessageToBinaryConverter - Class in org.springframework.integration.mongodb.support
 
MessageToBinaryConverter() - Constructor for class org.springframework.integration.mongodb.support.MessageToBinaryConverter
 
messageToMqttBytes(Message<?>) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Subclasses can override this method to convert the payload to a byte[].
MessageTransformationException - Exception in org.springframework.integration.transformer
Base Exception type for Message transformation errors.
MessageTransformationException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(Message<?>, String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformingHandler - Class in org.springframework.integration.transformer
A reply-producing MessageHandler that delegates to a Transformer instance to modify the received Message and sends the result to its output channel.
MessageTransformingHandler(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingHandler
Create a MessageTransformingHandler instance that delegates to the provided Transformer.
MessageTriggerAction - Interface in org.springframework.integration.handler
Classes implementing this interface can take some action when a trigger Message is received.
MessageValidator - Class in org.springframework.integration.test.support
Validate a message.
MessageValidator() - Constructor for class org.springframework.integration.test.support.MessageValidator
 
messageWithHeaderEntries(Map<String, ?>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderEntry(String, Object) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderEntry(String, Matcher<T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderKey(String) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithPayload(Matcher<? super T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithPayload(T) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
MESSAGING_ANNOTATION_POSTPROCESSOR_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
MessagingAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
A BeanPostProcessor implementation that processes method-level messaging annotations such as @Transformer, @Splitter, @Router, and @Filter.
MessagingAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
MessagingAnnotationUtils - Class in org.springframework.integration.util
Utility methods to support annotation processing.
messagingAwareMapper(String...) - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Return an ObjectMapper if available, supplied with Message specific serializers and deserializers.
MessagingEvent - Class in org.springframework.integration.event.core
A subclass of ApplicationEvent that wraps a Message.
MessagingEvent(Message<?>) - Constructor for class org.springframework.integration.event.core.MessagingEvent
 
MessagingExceptionWrapper - Exception in org.springframework.integration.support
A wrapper exception for a MessagingException used to convey the cause and original message to a MessagePublishingErrorHandler.
MessagingExceptionWrapper(Message<?>, MessagingException) - Constructor for exception org.springframework.integration.support.MessagingExceptionWrapper
 
MessagingGateway - Annotation Type in org.springframework.integration.annotation
A stereotype annotation to provide an Integration Messaging Gateway Proxy (<gateway/>) as an abstraction over the messaging API.
MessagingGatewayRegistrar - Class in org.springframework.integration.config
The ImportBeanDefinitionRegistrar to parse MessagingGateway and its service-interface and to register BeanDefinition GatewayProxyFactoryBean.
MessagingGatewayRegistrar() - Constructor for class org.springframework.integration.config.MessagingGatewayRegistrar
 
MessagingGatewaySpec<S extends MessagingGatewaySpec<S,G>,G extends MessagingGatewaySupport> - Class in org.springframework.integration.dsl
MessagingGatewaySpec(G) - Constructor for class org.springframework.integration.dsl.MessagingGatewaySpec
 
MessagingGatewaySupport - Class in org.springframework.integration.gateway
A convenient base class for connecting application code to MessageChannels for sending, receiving, or request-reply operations.
MessagingGatewaySupport() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
Construct an instance that will return null if no reply is received.
MessagingGatewaySupport(boolean) - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
If errorOnTimeout is true, construct an instance that will send an ErrorMessage with a MessageTimeoutException payload to the error channel if a reply is expected but none is received.
MessagingMethodInvokerHelper - Class in org.springframework.integration.handler.support
A helper class for processors that invoke a method on a target Object using a combination of message payload(s) and headers as arguments.
MessagingMethodInvokerHelper(Object, Method, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Method, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper.ParametersWrapper - Class in org.springframework.integration.handler.support
 
messagingTemplate - Variable in class org.springframework.integration.core.ErrorMessagePublisher
 
MessagingTemplate - Class in org.springframework.integration.core
 
MessagingTemplate() - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with no default channel.
MessagingTemplate(MessageChannel) - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with the given default channel.
messagingTemplate - Variable in class org.springframework.integration.gateway.MessagingGatewaySupport
 
messagingTemplate - Variable in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
messagingTemplateFor(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow for provided flowId.
messagingTemplateFor(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow for provided flowId.
metadata(Function<Message<P>, Map<Object, MimeType>>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a Function to evaluate a metadata as a Map<Object, MimeType> for RSocket request against request message.
metadata(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate a metadata as a Map<Object, MimeType> for the RSocket request against request message.
metadata(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate a metadata as a Map<Object, MimeType> for the RSocket request type at runtime against a request message.
METADATA_STORE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
metadataStore(MetadataStore) - Method in class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
 
MetadataStore - Interface in org.springframework.integration.metadata
Strategy interface for storing metadata from certain adapters to avoid duplicate delivery of messages, for example.
MetadataStoreListener - Interface in org.springframework.integration.metadata
A callback to be invoked whenever a value changes in the data store.
MetadataStoreListenerAdapter - Class in org.springframework.integration.metadata
Base implementation for a MetadataStoreListener.
MetadataStoreListenerAdapter() - Constructor for class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
metadataStorePrefix(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a prefix for remote files metadata keys.
MetadataStoreSelector - Class in org.springframework.integration.selector
MetadataStoreSelector(MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
METER_PREFIX - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
 
MeterFacade - Interface in org.springframework.integration.support.management.metrics
Facade for Meters.
meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
 
meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
 
meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
 
meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
 
meters - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
method(RequestMethod...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
List of supported HTTP request methods, e.g.
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
MethodAnnotationPostProcessor<T extends Annotation> - Interface in org.springframework.integration.config.annotation
Strategy interface for post-processing annotated methods.
MethodAnnotationPublisherMetadataSource - Class in org.springframework.integration.aop
An PublisherMetadataSource implementation that retrieves the channel name and expression strings from an annotation.
MethodAnnotationPublisherMetadataSource() - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodAnnotationPublisherMetadataSource(Set<Class<? extends Annotation>>) - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodArgsHolder - Class in org.springframework.integration.gateway
Simple wrapper class containing a Method and an object array containing the arguments for an invocation of that method.
MethodArgsHolder(Method, Object[]) - Constructor for class org.springframework.integration.gateway.MethodArgsHolder
 
MethodArgsMessageMapper - Interface in org.springframework.integration.gateway
Implementations of this interface are InboundMessageMappers that map a MethodArgsHolder to a Message.
MethodInvokingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that works as an adapter to another bean.
MethodInvokingCorrelationStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingCorrelationStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingMessageGroupProcessor - Class in org.springframework.integration.aggregator
MessageGroupProcessor that serves as an adapter for the invocation of a POJO method.
MethodInvokingMessageGroupProcessor(Object) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that invokes the specified method on the provided object.
MethodInvokingMessageHandler(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageHandler(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageListProcessor<T> - Class in org.springframework.integration.aggregator
A MessageListProcessor implementation that invokes a method on a target POJO.
MethodInvokingMessageListProcessor(Object, Method, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageProcessor<T> - Class in org.springframework.integration.handler
A MessageProcessor implementation that invokes a method on a target Object.
MethodInvokingMessageProcessor(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String, boolean) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageSource - Class in org.springframework.integration.endpoint
A MessageSource implementation that invokes a no-argument method so that its return value may be sent to a channel.
MethodInvokingMessageSource() - Constructor for class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
MethodInvokingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that invokes a method on a plain old Java object.
MethodInvokingReleaseStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingReleaseStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingRouter - Class in org.springframework.integration.router
A Message Router that invokes the specified method on the given object.
MethodInvokingRouter(Object, Method) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object, String) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingSelector - Class in org.springframework.integration.filter
A method-invoking implementation of MessageSelector.
MethodInvokingSelector(Object, Method) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object, String) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that invokes the specified method on the given object.
MethodInvokingSplitter(Object, Method) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object, String) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that invokes the specified method on the given object.
MethodInvokingTransformer(Object, Method) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object, String) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
methodIsHandleMessageOrEmpty(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
MethodNameMappingPublisherMetadataSource - Class in org.springframework.integration.aop
 
MethodNameMappingPublisherMetadataSource(Map<String, String>) - Constructor for class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
methods(HttpMethod...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
The HTTP request methods to map to, narrowing the primary mapping: GET, POST, HEAD, OPTIONS, PUT, PATCH, DELETE, TRACE.
MetricsCaptor - Interface in org.springframework.integration.support.management.metrics
A metrics facade that delegates to a concrete implementation.
MetricsCaptor.CounterBuilder - Interface in org.springframework.integration.support.management.metrics
A builder for a counter.
MetricsCaptor.GaugeBuilder - Interface in org.springframework.integration.support.management.metrics
A builder for a gauge.
MetricsCaptor.TimerBuilder - Interface in org.springframework.integration.support.management.metrics
A builder for a timer.
mGet(Message<?>, Session<F>, String, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
mGet(Message<?>, Session<FTPFile>, String, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
MicroCounter(Counter, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
MicroCounterBuilder(MeterRegistry, String) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
 
MicroGauge(Gauge, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
MicroGaugeBuilder(MeterRegistry, String, Object, ToDoubleFunction<Object>) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
 
MICROMETER_CAPTOR_NAME - Static variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
MicrometerMetricsCaptor - Class in org.springframework.integration.support.management.micrometer
The Micrometer implementation of MetricsCaptor.
MicrometerMetricsCaptor(MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
MicrometerMetricsCaptor.AbstractMeter<M extends io.micrometer.core.instrument.Meter> - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroCounter - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroCounterBuilder - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroGauge - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroGaugeBuilder - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroTimer - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptor.MicroTimerBuilder - Class in org.springframework.integration.support.management.micrometer
 
MicrometerMetricsCaptorRegistrar - Class in org.springframework.integration.support.management.micrometer
An ImportBeanDefinitionRegistrar to conditionally add a MicrometerMetricsCaptor bean when io.micrometer.core.instrument.MeterRegistry is present in classpath and no MicrometerMetricsCaptor.MICROMETER_CAPTOR_NAME bean present yet.
MicrometerMetricsCaptorRegistrar() - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorRegistrar
 
MicrometerNodeEnhancer - Class in org.springframework.integration.graph
Add micrometer metrics to the node.
MicroTimer(Timer, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
MimeTypeSerializer - Class in org.springframework.integration.support.json
Simple StdSerializer extension to represent a MimeType object in the target JSON as a plain string.
MimeTypeSerializer() - Constructor for class org.springframework.integration.support.json.MimeTypeSerializer
 
MIN_REGISTRATION_VALUE - Static variable in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
minimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
minSubscribers(int) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
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.
mkdir(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
mkdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
mkdir(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
mkdir(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
MOCK_INTEGRATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.test.context.MockIntegrationContext
The bean name for the mock integration context.
MockIntegration - Class in org.springframework.integration.test.mock
The factory for integration specific mock components.
MockIntegrationContext - Class in org.springframework.integration.test.context
A BeanFactoryAware component with an API to customize real beans in the application context from test code.
MockIntegrationContext() - Constructor for class org.springframework.integration.test.context.MockIntegrationContext
 
MockitoMessageMatchers - Class in org.springframework.integration.test.matcher
Mockito matcher factory for Message matcher creation.
mockMessageHandler() - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a MockMessageHandler instance.
mockMessageHandler(ArgumentCaptor<Message<?>>) - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a MockMessageHandler instance based on the provided ArgumentCaptor.
MockMessageHandler - Class in org.springframework.integration.test.mock
The AbstractMessageProducingHandler extension for the mocking purpose in tests.
MockMessageHandler(ArgumentCaptor<Message<?>>) - Constructor for class org.springframework.integration.test.mock.MockMessageHandler
 
mockMessageSource(T) - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a mock for the MessageSource based on the provided payload.
mockMessageSource(T, T...) - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a mock for the MessageSource based on the provided payloads.
mockMessageSource(Message<?>) - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a mock for the MessageSource based on the provided message.
mockMessageSource(Message<?>, Message<?>...) - Static method in class org.springframework.integration.test.mock.MockIntegration
Build a mock for the MessageSource based on the provided messages.
modified(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
modified(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
 
modified(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
 
modified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
 
mongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
Configure a MongoConverter.
mongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
Configure a custom MongoConverter used to assist in deserialization data read from MongoDb.
MongoDb - Class in org.springframework.integration.mongodb.dsl
Factory class for building MongoDb components
MongoDbChangeStreamMessageProducer - Class in org.springframework.integration.mongodb.inbound
A MessageProducerSupport for MongoDB Change Stream implementation.
MongoDbChangeStreamMessageProducer(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
Create an instance based on the provided ReactiveMongoOperations.
MongoDbChangeStreamMessageProducerSpec - Class in org.springframework.integration.mongodb.dsl
MongoDbChangeStreamMessageProducerSpec(MongoDbChangeStreamMessageProducer) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Construct a builder based on an initial MongoDbChangeStreamMessageProducerSpec.
MongoDbChannelMessageStore - Class in org.springframework.integration.mongodb.store
MongoDB PriorityCapableChannelMessageStore implementation.
MongoDbChannelMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDatabaseFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
mongoDbFactory - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
MongoDbInboundChannelAdapterParser - Class in org.springframework.integration.mongodb.config
Parser for Mongodb store inbound adapters
MongoDbInboundChannelAdapterParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbInboundChannelAdapterParser
 
MongoDbMessageSource - Class in org.springframework.integration.mongodb.inbound
An instance of MessageSource which returns a Message with a payload which is the result of execution of a Query.
MongoDbMessageSource(MongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Creates an instance with the provided MongoDatabaseFactory and SpEL expression which should resolve to a MongoDb 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
MongoDbMessageSource(MongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Creates an instance with the provided MongoOperations and SpEL expression which should resolve to a Mongo 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
MongoDbMessageStore - Class in org.springframework.integration.mongodb.store
An implementation of both the MessageStore and MessageGroupStore strategies that relies upon MongoDB for persistence.
MongoDbMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
Create a MongoDbMessageStore using the provided MongoDatabaseFactory.and the default collection name.
MongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
Create a MongoDbMessageStore using the provided MongoDatabaseFactory and collection name.
MongoDbMetadataStore - Class in org.springframework.integration.mongodb.metadata
MongoDbMetadataStore implementation of ConcurrentMetadataStore.
MongoDbMetadataStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoDatabaseFactory and default collection name - MongoDbMetadataStore.DEFAULT_COLLECTION_NAME.
MongoDbMetadataStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoDatabaseFactory and collection name
MongoDbMetadataStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoTemplate and default collection name - MongoDbMetadataStore.DEFAULT_COLLECTION_NAME.
MongoDbMetadataStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoTemplate and collection name.
MongoDbNamespaceHandler - Class in org.springframework.integration.mongodb.config
Namespace handler for Spring Integration's 'mongodb' namespace.
MongoDbNamespaceHandler() - Constructor for class org.springframework.integration.mongodb.config.MongoDbNamespaceHandler
 
MongoDbOutboundChannelAdapterParser - Class in org.springframework.integration.mongodb.config
Parser for Mongodb store outbound adapters
MongoDbOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbOutboundChannelAdapterParser
 
MongoDbOutboundGateway - Class in org.springframework.integration.mongodb.outbound
Makes outbound operations to query a MongoDb database using a MongoOperations
MongoDbOutboundGateway(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
MongoDbOutboundGateway(MongoDatabaseFactory, MongoConverter) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
MongoDbOutboundGateway(MongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
MongoDbOutboundGatewayParser - Class in org.springframework.integration.mongodb.config
Parser for MongoDb outbound gateways
MongoDbOutboundGatewayParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbOutboundGatewayParser
 
MongoDbOutboundGatewaySpec - Class in org.springframework.integration.mongodb.dsl
A MessageHandlerSpec extension for the MongoDb Outbound endpoint MongoDbOutboundGateway
MongoDbOutboundGatewaySpec(MongoDatabaseFactory, MongoConverter) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
 
MongoDbOutboundGatewaySpec(MongoOperations) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
 
MongoDbStoringMessageHandler - Class in org.springframework.integration.mongodb.outbound
Implementation of MessageHandler which writes Message payload into a MongoDb collection identified by evaluation of the MongoDbStoringMessageHandler.collectionNameExpression.
MongoDbStoringMessageHandler(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
Will construct this instance using provided MongoDatabaseFactory
MongoDbStoringMessageHandler(MongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
Will construct this instance using fully created and initialized instance of provided MongoOperations
MongoHeaders - Class in org.springframework.integration.mongodb.support
Pre-defined names and prefixes to be used for for dealing with headers required by Mongo components
moved(ServerSession, Path, Path, Collection<CopyOption>, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
mPut(Message<?>, Session<F>, File) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Put files from the provided directory to the remote server recursively.
mPut(Message<?>, Session<FTPFile>, File) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
mputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
A FileListFilter that runs against the local file system view when using MPUT command.
mputFilterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
mputFilterFunction(Function<File, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
mqttBytesToPayload(MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Subclasses can override this method to convert the byte[] to a payload.
MqttComponent<T> - Interface in org.springframework.integration.mqtt.core
A component that interfaces with MQTT.
MqttConnectionFailedEvent - Class in org.springframework.integration.mqtt.event
 
MqttConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.mqtt.event.MqttConnectionFailedEvent
 
MqttHeaderAccessor - Class in org.springframework.integration.mqtt.support
Helper for typed access to incoming MQTT message headers.
MqttHeaders - Class in org.springframework.integration.mqtt.support
Spring Integration headers.
MqttIntegrationEvent - Class in org.springframework.integration.mqtt.event
Base class for Mqtt Events.
MqttIntegrationEvent(Object) - Constructor for class org.springframework.integration.mqtt.event.MqttIntegrationEvent
 
MqttIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.mqtt.event.MqttIntegrationEvent
 
MqttMessageConverter - Interface in org.springframework.integration.mqtt.support
Extension of MessageConverter allowing the topic to be added as a header.
MqttMessageDeliveredEvent - Class in org.springframework.integration.mqtt.event
An event emitted (when using aysnc) when the client indicates the message was delivered.
MqttMessageDeliveredEvent(Object, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageDeliveredEvent
 
MqttMessageDeliveryEvent - Class in org.springframework.integration.mqtt.event
Base class for events related to message delivery.
MqttMessageDeliveryEvent(Object, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
MqttMessageDrivenChannelAdapterParser - Class in org.springframework.integration.mqtt.config.xml
The MqttAdapter Message Driven Channel adapter parser
MqttMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttMessageDrivenChannelAdapterParser
 
MqttMessageSentEvent - Class in org.springframework.integration.mqtt.event
An event emitted (when using aysnc) when the client indicates that a message has been sent.
MqttMessageSentEvent(Object, Message<?>, String, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
MqttNamespaceHandler - Class in org.springframework.integration.mqtt.config.xml
The namespace handler for the MqttAdapter namespace
MqttNamespaceHandler() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttNamespaceHandler
 
MqttOutboundChannelAdapterParser - Class in org.springframework.integration.mqtt.config.xml
The parser for the MqttAdapter Outbound Channel Adapter.
MqttOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
 
MqttPahoClientFactory - Interface in org.springframework.integration.mqtt.core
 
MqttPahoComponent - Interface in org.springframework.integration.mqtt.core
An extension of MqttComponent for Eclipse Paho components.
MqttPahoMessageDrivenChannelAdapter - Class in org.springframework.integration.mqtt.inbound
Eclipse Paho Implementation.
MqttPahoMessageDrivenChannelAdapter(String, String, MqttPahoClientFactory, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Use this constructor for a single url (although it may be overridden if the server URI(s) are provided by the MqttConnectOptions.getServerURIs() provided by the MqttPahoClientFactory).
MqttPahoMessageDrivenChannelAdapter(String, MqttPahoClientFactory, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Use this constructor if the server URI(s) are provided by the MqttConnectOptions.getServerURIs() provided by the MqttPahoClientFactory.
MqttPahoMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Use this constructor when you don't need additional MqttConnectOptions.
MqttPahoMessageHandler - Class in org.springframework.integration.mqtt.outbound
Eclipse Paho Implementation.
MqttPahoMessageHandler(String, String, MqttPahoClientFactory) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Use this constructor for a single url (although it may be overridden if the server URI(s) are provided by the MqttConnectOptions.getServerURIs() provided by the MqttPahoClientFactory).
MqttPahoMessageHandler(String, MqttPahoClientFactory) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Use this constructor if the server URI(s) are provided by the MqttConnectOptions.getServerURIs() provided by the MqttPahoClientFactory.
MqttPahoMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Use this constructor when you don't need additional MqttConnectOptions.
MqttSubscribedEvent - Class in org.springframework.integration.mqtt.event
 
MqttSubscribedEvent(Object, String) - Constructor for class org.springframework.integration.mqtt.event.MqttSubscribedEvent
 
MqttUtils - Class in org.springframework.integration.mqtt.support
MQTT Utilities
MSGID - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
MulticastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
Channel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.
MulticastReceivingChannelAdapter(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
MulticastReceivingChannelAdapter(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
MulticastSendingMessageHandler - Class in org.springframework.integration.ip.udp
A MessageHandler implementation that maps a Message into a UDP datagram packet and sends that to the specified multicast address (224.0.0.0 to 239.255.255.255) and port.
MulticastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port.
MulticastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the lengthCheck option (if set, a length is prepended to the packet and checked at the destination).
MulticastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
MulticastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
MulticastSendingMessageHandler(Expression) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Construct MulticastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
MulticastSendingMessageHandler(String) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Construct MulticastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
MULTIPART_MODE - Static variable in class org.springframework.integration.mail.MailHeaders
 
MultipartAwareFormHttpMessageConverter - Class in org.springframework.integration.http.converter
An HttpMessageConverter implementation that delegates to an instance of AllEncompassingFormHttpMessageConverter while adding the capability to read multipart/form-data content in an HTTP request.
MultipartAwareFormHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
MultipartFileReader<T> - Interface in org.springframework.integration.http.multipart
Strategy for reading MultipartFile content.
MultipartHttpInputMessage - Class in org.springframework.integration.http.multipart
 
MultipartHttpInputMessage(MultipartHttpServletRequest) - Constructor for class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
multipartMode(int) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a multipart mode to use.
multipartModeExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set an expression that is evaluated to determine a multipart mode to use.
multipartModeFunction(Function<Message<P>, Integer>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that is invoked to determine a multipart mode to use.
multipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
Specify the MultipartResolver to use when checking requests.
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.
MutableMessage<T> - Class in org.springframework.integration.support
An implementation of Message with a generic payload.
MutableMessage(T) - Constructor for class org.springframework.integration.support.MutableMessage
 
MutableMessage(T, Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessage
 
MutableMessage(T, MutableMessageHeaders) - Constructor for class org.springframework.integration.support.MutableMessage
 
MutableMessageBuilder<T> - Class in org.springframework.integration.support
Specialized message builder that can be used within a component to avoid the overhead of having to build multiple messages for mutations within that component.
MutableMessageBuilderFactory - Class in org.springframework.integration.support
 
MutableMessageBuilderFactory() - Constructor for class org.springframework.integration.support.MutableMessageBuilderFactory
 
MutableMessageHeaders - Class in org.springframework.integration.support
A MessageHeaders that permits direct access to and modification of the header map.
MutableMessageHeaders(Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessageHeaders
 
MutableMessageHeaders(Map<String, Object>, UUID, Long) - Constructor for class org.springframework.integration.support.MutableMessageHeaders
 
MutableMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the MutableMessage.
MutableMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
 
mv(Message<?>, Session<F>, String, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Move one remote path to another.
mv(Message<?>, Session<FTPFile>, String, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
MySqlChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
MySqlChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 

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
 
NAME_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
NamedComponent - Interface in org.springframework.integration.support.context
 
NamedFieldsMBeanAttributeFilter - Class in org.springframework.integration.jmx
 
NamedFieldsMBeanAttributeFilter(String...) - Constructor for class org.springframework.integration.jmx.NamedFieldsMBeanAttributeFilter
 
namedQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify a name a named JPQL based query or a native SQL query.
namedQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a name a named JPQL based query or a native SQL query.
nativeOptions(String) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
Specify the options string for native tail command.
nativeQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify a native SQL query to perform persistent operation.
nativeQuery(String) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a native SQL query to perform persistent operation.
NET_CONNECTION_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
netClient(String, int) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create a client spec that does not use NIO.
netServer(int) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create a server spec that does not use NIO.
newInstance() - Static method in class org.springframework.integration.support.json.JsonObjectMapperProvider
Return an object mapper if available.
next() - Method in class org.springframework.integration.util.FunctionIterator
 
nextExecutionTime(TriggerContext) - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
nextExecutionTime(TriggerContext) - Method in class org.springframework.integration.util.CompoundTrigger
 
nextExecutionTime(TriggerContext) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Return the time after which a task should run again.
NILVALUE - Static variable in class org.springframework.integration.syslog.RFC5424SyslogParser
 
NIO_CONNECTION_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
nioClient(String, int) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create a client spec that uses NIO.
NioFileLocker - Class in org.springframework.integration.file.locking
File locking strategy that uses java.nio.
NioFileLocker() - Constructor for class org.springframework.integration.file.locking.NioFileLocker
 
nioHarvestInterval(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
nioLocker() - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Configure an NioFileLocker.
nioServer(int) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create a server spec that uses NIO.
nlst(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
List remote files names for the provided directory.
nlst(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
noAutoAck() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
Disable auto acknowledgment by a SourcePollingChannelAdapter or MessageSourcePollingTemplate.
noAutoAck() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
noAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
noChannelKeyFallback() - Method in class org.springframework.integration.dsl.RouterSpec
By default, if a resolved channel key does not exist in the channel map, the key itself is used as the channel name, which we will attempt to resolve to a channel.
NODE - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 
NODE_LIST - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 
nodeToDocument(Node) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
noEndpointsRunning(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return true if none of the endpoints in the role are running or if there are no endpoints in the role.
NoListenerException - Exception in org.springframework.integration.ip.tcp.connection
 
NoListenerException(String, Throwable) - Constructor for exception org.springframework.integration.ip.tcp.connection.NoListenerException
 
NoListenerException(String) - Constructor for exception org.springframework.integration.ip.tcp.connection.NoListenerException
 
NON_READABLE_BODY_HTTP_METHODS - Static variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
NON_STANDARD_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that matches any header that is not a standard header (i.e.
noRouterAttributesProvided() - Method in class org.springframework.integration.config.RouterFactoryBean
 
NOTIFICATION_HANDBACK - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
NOTIFICATION_TYPE - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
NotificationListeningChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
NotificationListeningChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
NotificationListeningMessageProducer - Class in org.springframework.integration.jmx
A JMX NotificationListener implementation that will send Messages containing the JMX Notification instances as their payloads.
NotificationListeningMessageProducer() - Constructor for class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
NotificationPublishingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
NotificationPublishingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
NotificationPublishingMessageHandler - Class in org.springframework.integration.jmx
An AbstractMessageHandler implementation to publish an incoming message as a JMX Notification.
NotificationPublishingMessageHandler(ObjectName) - Constructor for class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
NotificationPublishingMessageHandler(String) - Constructor for class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
NotificationPublishingMessageHandler.PublisherDelegate - Class in org.springframework.integration.jmx
Simple class used for the actual MBean instances to be registered.
NotNamedFieldsMBeanAttributeFilter - Class in org.springframework.integration.jmx
 
NotNamedFieldsMBeanAttributeFilter(String...) - Constructor for class org.springframework.integration.jmx.NotNamedFieldsMBeanAttributeFilter
 
notPropagatedHeaders(String...) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Set header patterns ("xxx*", "*xxx", "*xxx*" or "xxx*yyy") that will NOT be copied from the inbound message.
NULL - Static variable in class org.springframework.integration.annotation.AnnotationConstants
Constant defining a value as a replacement for null which we cannot use in annotation attributes.
NULL_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
NullAwarePayloadArgumentResolver - Class in org.springframework.integration.support
A PayloadMethodArgumentResolver that treats KafkaNull payloads as null.
NullAwarePayloadArgumentResolver(MessageConverter) - Constructor for class org.springframework.integration.support.NullAwarePayloadArgumentResolver
 
NullAwarePayloadArgumentResolver(MessageConverter, Validator) - Constructor for class org.springframework.integration.support.NullAwarePayloadArgumentResolver
 
NullChannel - Class in org.springframework.integration.channel
A channel implementation that essentially behaves like "/dev/null".
NullChannel() - Constructor for class org.springframework.integration.channel.NullChannel
 
nullChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Add a bean into this flow definition as a terminal operator.
NUMBER - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 

O

OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
ObjectStringMapBuilder - Class in org.springframework.integration.support
A map builder creating a map with Object keys and String values.
ObjectStringMapBuilder() - Constructor for class org.springframework.integration.support.ObjectStringMapBuilder
 
ObjectStringMessageConverter - Class in org.springframework.integration.support.converter
A StringMessageConverter extension to convert any object to string.
ObjectStringMessageConverter() - Constructor for class org.springframework.integration.support.converter.ObjectStringMessageConverter
 
ObjectToJsonTransformer - Class in org.springframework.integration.json
Transformer implementation that converts a payload instance into a JSON string representation.
ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer.ResultType - Enum in org.springframework.integration.json
 
ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
ObjectToMapTransformer - Class in org.springframework.integration.transformer
Transforms an object graph into a Map.
ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
Construct with the default JsonObjectMapper instance available via factory.
ObjectToMapTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
Construct with the provided JsonObjectMapper instance.
ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
objectToString() - Static method in class org.springframework.integration.dsl.Transformers
 
objectToString(String) - Static method in class org.springframework.integration.dsl.Transformers
 
ObjectToStringTransformer - Class in org.springframework.integration.transformer
A simple transformer that creates an outbound payload by invoking the inbound payload Object's toString() method.
ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
 
ObjectToStringTransformer(String) - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
 
ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'object-to-string-transformer' element.
ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
obtain(Object) - Method in class org.springframework.integration.gemfire.util.GemfireLockRegistry
 
obtain(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
obtain(Object) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
 
obtain(Object) - Method in class org.springframework.integration.support.locks.DefaultLockRegistry
Obtains a lock by masking the lockKey's hashCode() with the mask and using the result as an index to the lock table.
obtain(Object) - Method in interface org.springframework.integration.support.locks.LockRegistry
Obtains the lock associated with the parameter object.
obtain(Object) - Method in class org.springframework.integration.support.locks.PassThruLockRegistry
 
obtain(Object) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
 
obtainComponentName(NamedComponent) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Obtain a component name from the provided NamedComponent.
obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
 
obtainConnection(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
obtainGroupTimeout(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EndpointSpec
Try to get a MessageChannel as an input for the provided IntegrationFlow or create one and wrap the provided flow to a new one.
obtainInputChannelFromFlow(IntegrationFlow, boolean) - Method in class org.springframework.integration.dsl.EndpointSpec
Try to get a MessageChannel as an input for the provided IntegrationFlow or create one and wrap the provided flow to a new one.
obtainNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
 
obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
 
obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
obtainSecurityMetadataSource() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
obtainSharedConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
obtainSizeIfPossible(Iterable<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Obtain a size of the provided Iterable.
obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Obtain a size of the provided Iterator.
obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
onAdd(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is added to the store
onAdd(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
onAppendEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.graph.IntegrationGraphServer
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.handler.DelayHandler
Handles ContextRefreshedEvent to invoke DelayHandler.reschedulePersistedMessages() as late as possible after application context startup.
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
HttpRequestHandlingEndpointSupports may depend on auto-created requestChannels, so MVC Handlers detection should be postponed as late as possible.
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
The NotificationListener might not be registered on AbstractEndpoint.start() because the MBeanExporter might not been started yet.
onApplicationEvent(AbstractLeaderEvent) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
HttpRequestHandlingEndpointSupports may depend on auto-created requestChannels, so MVC Handlers detection should be postponed as late as possible.
onClose(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
onComplete() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
onConnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onCreate(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
onDeleteEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onDisconnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onError(Throwable) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
onEvent(CqEvent) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
OnFailedToAcquireMutexEvent - Class in org.springframework.integration.leader.event
Generic event representing that a mutex could not be acquired during leader election.
OnFailedToAcquireMutexEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnFailedToAcquireMutexEvent
Instantiate a new OnFailedToAcquireMutexEvent.
onFailure(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
Adds the failed message back to the 'toBeReceived' queue if there is room.
onGranted(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
 
onGranted(Context) - Method in interface org.springframework.integration.leader.Candidate
Callback method invoked when this candidate is elected leader.
onGranted(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
 
OnGrantedEvent - Class in org.springframework.integration.leader.event
Generic event representing that leader has been granted.
OnGrantedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnGrantedEvent
Instantiates a new granted event.
onInit() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
onInit() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
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
 
onInit() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
onInit() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
onInit() - Method in class org.springframework.integration.channel.DirectChannel
 
onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
 
onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Callback method for initialization.
onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this for initialization logic.
onInit() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
onInit() - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
onInit() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
onInit() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
onInit() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
onInit() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
onInit() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
onInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
onInit() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
onInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
onInit() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
onInit() - Method in class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
 
onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
onInit() - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
onInit() - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
 
onInit() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
onInit() - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
onInit() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.LoggingHandler
 
onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
onInit() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
 
onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Locates the MultipartResolver bean based on the default name defined by the DispatcherServlet.MULTIPART_RESOLVER_BEAN_NAME constant if available.
onInit() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
onInit() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
 
onInit() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
onInit() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
onInit() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
onInit() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
onInit() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
onInit() - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
 
onInit() - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
onInit() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
onInit() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
onInit() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
onInit() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
onInit() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
onInit() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
onInit() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
onInit() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
Check for mandatory attributes
onInit() - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
onInit() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
onInit() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
onInit() - Method in class org.springframework.integration.mail.ImapMailReceiver
 
onInit() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
 
onInit() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
 
onInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
 
onInit() - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
 
onInit() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
onInit() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
onInit() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
onInit() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
 
onInit() - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
 
onInit() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
onInit() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
 
onInit() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
onInit() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
onInit() - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
 
onInit() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
onInit() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
onInit() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
 
onInit() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
onInit() - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
onInit() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
onInit() - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
onInit() - Method in class org.springframework.integration.router.RecipientListRouter
 
onInit() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
 
onInit() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
onInit() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
onInit() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
onInit() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
onInit() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
onInit() - Method in class org.springframework.integration.transformer.DecodingTransformer
 
onInit() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
onInit() - Method in class org.springframework.integration.transformer.HeaderFilter
 
onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
onInit() - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
onInit() - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
 
onInit() - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
 
onInit() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
onInit() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
onInit() - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
onInit() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
onInit() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
onInit() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
onInit() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
onInit() - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
onInit() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
onInit() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
 
OnlyOnceTrigger - Class in org.springframework.integration.test.util
 
OnlyOnceTrigger() - Constructor for class org.springframework.integration.test.util.OnlyOnceTrigger
 
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
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
onMessage(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpListener
Called by a TCPConnection when a new message arrives.
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
onMessage(Message, Session) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
onMessage(Message) - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
onMessage(Message<?>) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
onMessage(WebSocketSession, WebSocketMessage<?>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
onMessage(WebSocketSession, WebSocketMessage<?>) - Method in interface org.springframework.integration.websocket.WebSocketListener
Handle the received WebSocketMessage.
onMessageBatch(List<Message>, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
 
onMkdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onNext(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
onRemove(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is removed from the store
onRemove(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
onRenameEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onRevoked(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
 
onRevoked(Context) - Method in interface org.springframework.integration.leader.Candidate
Callback method invoked when this candidate is no longer leader.
onRevoked(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
 
OnRevokedEvent - Class in org.springframework.integration.leader.event
Generic event representing that leader has been revoked.
OnRevokedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnRevokedEvent
Instantiates a new revoked event.
onRmdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
onRotation(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
Update the state of the MessageSource after the server is rotated, if necessary.
onSubscribe(Subscription) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
onUpdate(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is updated into the store
onUpdate(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
onUploadEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
openFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
OPERATION_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
OperationInvokingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
OperationInvokingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
OperationInvokingMessageHandler - Class in org.springframework.integration.jmx
A MessageHandler implementation for invoking JMX operations based on the Message sent to its AbstractMessageHandler.handleMessage(Message) method.
OperationInvokingMessageHandler(MBeanServerConnection) - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
Construct an instance based on the provided MBeanServerConnection.
OperationInvokingOutboundGatewayParser - Class in org.springframework.integration.jmx.config
 
OperationInvokingOutboundGatewayParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
options(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify the array of options for various gateway commands.
options(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify the array of AbstractRemoteFileOutboundGateway.Option for various gateway commands.
options(ChangeStreamOptions) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Configure a ChangeStreamOptions.
OracleChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
Contains Oracle-specific queries for the JdbcChannelMessageStore.
OracleChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
ORDER - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
order(int) - Method in class org.springframework.integration.dsl.BarrierSpec
 
order(int) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
Orderable - Interface in org.springframework.integration.context
Interface that extends Ordered while also exposing the Orderable.setOrder(int) as an interface-level so that it is avaiable on AOP proxies, etc.
OrderlyShutdownCapable - Interface in org.springframework.integration.context
Interface for components that wish to be considered for an orderly shutdown using management interfaces.
orderlyShutdownCapableComponentsAfter() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
orderlyShutdownCapableComponentsBefore() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
org.springframework.integration - package org.springframework.integration
Base package for Spring Integration Core.
org.springframework.integration.acks - package org.springframework.integration.acks
Provides classes related to message acknowledgment.
org.springframework.integration.aggregator - package org.springframework.integration.aggregator
Provides classes related to message aggregation.
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.
org.springframework.integration.annotation - package org.springframework.integration.annotation
Provides annotations for annotation-based configuration.
org.springframework.integration.aop - package org.springframework.integration.aop
Provides classes to support message publication using AOP.
org.springframework.integration.channel - package org.springframework.integration.channel
Provides classes representing various channel types.
org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
Provides classes related to channel interception.
org.springframework.integration.codec - package org.springframework.integration.codec
Provides base classes for the Codec abstraction.
org.springframework.integration.codec.kryo - package org.springframework.integration.codec.kryo
The Kryo specific Codec classes.
org.springframework.integration.config - package org.springframework.integration.config
Base package for configuration.
org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
Provides classes supporting annotation-based configuration.
org.springframework.integration.config.xml - package org.springframework.integration.config.xml
Provides supporting XML-based configuration - parsers, namespace handlers.
org.springframework.integration.context - package org.springframework.integration.context
Provides classes relating to application context configuration.
org.springframework.integration.core - package org.springframework.integration.core
Provides core classes.
org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
Provides classes related to dispatching messages.
org.springframework.integration.dsl - package org.springframework.integration.dsl
Root package of the Spring Integration Java DSL.
org.springframework.integration.dsl.context - package org.springframework.integration.dsl.context
The context support classes for Spring Integration Java DSL.
org.springframework.integration.dsl.support - package org.springframework.integration.dsl.support
Provides various support classes used across Spring Integration Java DSL Components.
org.springframework.integration.endpoint - package org.springframework.integration.endpoint
Provides core classes related to Endpoints.
org.springframework.integration.event.config - package org.springframework.integration.event.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.event.core - package org.springframework.integration.event.core
Provides Event core classes.
org.springframework.integration.event.inbound - package org.springframework.integration.event.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.event.outbound - package org.springframework.integration.event.outbound
Provides classes supporting outbound endpoints.
org.springframework.integration.events - package org.springframework.integration.events
ApplicationEvents generated by the Spring Integration framework.
org.springframework.integration.expression - package org.springframework.integration.expression
Provides classes supporting SpEL expressions.
org.springframework.integration.feed.config - package org.springframework.integration.feed.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.feed.dsl - package org.springframework.integration.feed.dsl
Provides Feed Components support for Spring Integration Java DSL.
org.springframework.integration.feed.inbound - package org.springframework.integration.feed.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.file - package org.springframework.integration.file
Base package for File support.
org.springframework.integration.file.config - package org.springframework.integration.file.config
Provides classes for configuration - parsers, namespace handlers, factory beans.
org.springframework.integration.file.dsl - package org.springframework.integration.file.dsl
Provides File Components support for Spring Integration Java DSL.
org.springframework.integration.file.event - package org.springframework.integration.file.event
ApplicationEvents generated by the file module.
org.springframework.integration.file.filters - package org.springframework.integration.file.filters
Provides classes supporting file filtering.
org.springframework.integration.file.locking - package org.springframework.integration.file.locking
Provides classes supporting file locking.
org.springframework.integration.file.remote - package org.springframework.integration.file.remote
Base package for supporting remote files.
org.springframework.integration.file.remote.aop - package org.springframework.integration.file.remote.aop
Provides classes related to AOP.
org.springframework.integration.file.remote.gateway - package org.springframework.integration.file.remote.gateway
Provides classes supporting remote file gateways.
org.springframework.integration.file.remote.handler - package org.springframework.integration.file.remote.handler
Provides classes supporting remote file message handlers.
org.springframework.integration.file.remote.server - package org.springframework.integration.file.remote.server
Provides classes related to file servers.
org.springframework.integration.file.remote.session - package org.springframework.integration.file.remote.session
Provides classes supporting remote file sessions.
org.springframework.integration.file.remote.synchronizer - package org.springframework.integration.file.remote.synchronizer
Provides classes supporting the synchronization of remote and local file directories.
org.springframework.integration.file.splitter - package org.springframework.integration.file.splitter
Provides implementations of AbstractMessageSplitter.
org.springframework.integration.file.support - package org.springframework.integration.file.support
Provides various support classes used across Spring Integration File Components.
org.springframework.integration.file.tail - package org.springframework.integration.file.tail
Classes used for tailing file system files.
org.springframework.integration.file.transformer - package org.springframework.integration.file.transformer
Provides classes supporting the transformation of file contents to messages.
org.springframework.integration.filter - package org.springframework.integration.filter
Provides classes supporting the filter pattern.
org.springframework.integration.ftp.config - package org.springframework.integration.ftp.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.ftp.dsl - package org.springframework.integration.ftp.dsl
Provides FTP Components for the Java DSL.
org.springframework.integration.ftp.filters - package org.springframework.integration.ftp.filters
Provides classes supporting FTP file filtering.
org.springframework.integration.ftp.gateway - package org.springframework.integration.ftp.gateway
Provides classes supporting FTP gateways.
org.springframework.integration.ftp.inbound - package org.springframework.integration.ftp.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.ftp.outbound - package org.springframework.integration.ftp.outbound
Provides classes for the FTP outbound channel adapter.
org.springframework.integration.ftp.server - package org.springframework.integration.ftp.server
Provides classes related to FTP servers.
org.springframework.integration.ftp.session - package org.springframework.integration.ftp.session
Provides classes supporting FTP sessions.
org.springframework.integration.gateway - package org.springframework.integration.gateway
Provides classes supporting messaging gateways.
org.springframework.integration.gemfire.config.xml - package org.springframework.integration.gemfire.config.xml
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.gemfire.inbound - package org.springframework.integration.gemfire.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.gemfire.metadata - package org.springframework.integration.gemfire.metadata
Provides classes for the Gemfire MetadataStore.
org.springframework.integration.gemfire.outbound - package org.springframework.integration.gemfire.outbound
Provides classes supporting outbound endpoints.
org.springframework.integration.gemfire.store - package org.springframework.integration.gemfire.store
Provides classes releated to storing messages.
org.springframework.integration.gemfire.util - package org.springframework.integration.gemfire.util
Provides utility classes.
org.springframework.integration.graph - package org.springframework.integration.graph
Provides classes related to the runtime object graph.
org.springframework.integration.groovy - package org.springframework.integration.groovy
Base package for Groovy support.
org.springframework.integration.groovy.config - package org.springframework.integration.groovy.config
Provides classes for configuration - parsers, namespace handlers, factory beans.
org.springframework.integration.handler - package org.springframework.integration.handler
Provides classes implementing various types of message handler.
org.springframework.integration.handler.advice - package org.springframework.integration.handler.advice
Provides classes that are used to advise MessageHandlers with cross-cutting concerns.
org.springframework.integration.handler.support - package org.springframework.integration.handler.support
Provides classes for message handlers support.
org.springframework.integration.history - package org.springframework.integration.history
Provides classes supporting the capture of message history.
org.springframework.integration.http - package org.springframework.integration.http
Base package for Http support.
org.springframework.integration.http.config - package org.springframework.integration.http.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.http.converter - package org.springframework.integration.http.converter
Provides classes supporting message conversion.
org.springframework.integration.http.dsl - package org.springframework.integration.http.dsl
Provides HTTP Components support for Spring Integration Java DSL.
org.springframework.integration.http.inbound - package org.springframework.integration.http.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.http.management - package org.springframework.integration.http.management
Provides classes related to management support.
org.springframework.integration.http.multipart - package org.springframework.integration.http.multipart
Provides classes supporting multipart HTTP requests.
org.springframework.integration.http.outbound - package org.springframework.integration.http.outbound
Provides classes supporting outbound endpoints.
org.springframework.integration.http.support - package org.springframework.integration.http.support
Provides classes to support Http endpoints, including header mapping.
org.springframework.integration.ip - package org.springframework.integration.ip
Base package for IP (TCP/UDP) Support.
org.springframework.integration.ip.config - package org.springframework.integration.ip.config
Provides classes for configuration - parsers, namespace handlers, factory beans.
org.springframework.integration.ip.dsl - package org.springframework.integration.ip.dsl
Provides TCP/UDP Component support for the Java DSL.
org.springframework.integration.ip.event - package org.springframework.integration.ip.event
ApplicationEvents generated by the ip module.
org.springframework.integration.ip.tcp - package org.springframework.integration.ip.tcp
Base package for TCP Support.
org.springframework.integration.ip.tcp.connection - package org.springframework.integration.ip.tcp.connection
All things related to tcp connections - client and server factories; listener and sender interfaces.
org.springframework.integration.ip.tcp.serializer - package org.springframework.integration.ip.tcp.serializer
Byte array (de)serializers for putting some protocol on the wire so that incoming messages can be constructed from stream data.
org.springframework.integration.ip.udp - package org.springframework.integration.ip.udp
Base package for UDP support.
org.springframework.integration.ip.util - package org.springframework.integration.ip.util
Provides utilities for IP support.
org.springframework.integration.jdbc - package org.springframework.integration.jdbc
Root package of the Spring Integration JDBC module, which contains various JDBC and Stored Procedure/Function supporting components.
org.springframework.integration.jdbc.config - package org.springframework.integration.jdbc.config
Contains parser classes for the JDBC namespace support.
org.springframework.integration.jdbc.lock - package org.springframework.integration.jdbc.lock
 
org.springframework.integration.jdbc.metadata - package org.springframework.integration.jdbc.metadata
Contains JDBC implementation of MetadataStore
org.springframework.integration.jdbc.store - package org.springframework.integration.jdbc.store
Provides JDBC-backed Message Store implementations.
org.springframework.integration.jdbc.store.channel - package org.springframework.integration.jdbc.store.channel
Provides support classes for the JdbcChannelMessageStore.
org.springframework.integration.jdbc.storedproc - package org.springframework.integration.jdbc.storedproc
Provides Stored Procedure/Function supporting classes.
org.springframework.integration.jms - package org.springframework.integration.jms
Base package for JMS Support.
org.springframework.integration.jms.config - package org.springframework.integration.jms.config
Provides classes for configuration - parsers, namespace handlers, factory beans.
org.springframework.integration.jms.dsl - package org.springframework.integration.jms.dsl
Provides JMS Component support for the Java DSL.
org.springframework.integration.jms.util - package org.springframework.integration.jms.util
 
org.springframework.integration.jmx - package org.springframework.integration.jmx
Base package for JMX support.
org.springframework.integration.jmx.config - package org.springframework.integration.jmx.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.jpa.config.xml - package org.springframework.integration.jpa.config.xml
Provides parser classes to provide Xml namespace support for the Jpa components.
org.springframework.integration.jpa.core - package org.springframework.integration.jpa.core
Provides core classes of the JPA module.
org.springframework.integration.jpa.dsl - package org.springframework.integration.jpa.dsl
Provides JPA Components support for Java DSL.
org.springframework.integration.jpa.inbound - package org.springframework.integration.jpa.inbound
Provides inbound Spring Integration Jpa components.
org.springframework.integration.jpa.outbound - package org.springframework.integration.jpa.outbound
Provides Spring Integration components for doing outbound operations.
org.springframework.integration.jpa.support - package org.springframework.integration.jpa.support
Provides various support classes used across Spring Integration Jpa Components.
org.springframework.integration.jpa.support.parametersource - package org.springframework.integration.jpa.support.parametersource
Provides generic support for ParameterSources and ParameterSource Factories.
org.springframework.integration.json - package org.springframework.integration.json
Provides classes supporting JSON in Spring Integration.
org.springframework.integration.kafka.channel - package org.springframework.integration.kafka.channel
Provides classes related to message channels.
org.springframework.integration.kafka.config.xml - package org.springframework.integration.kafka.config.xml
Provides parser classes to provide Xml namespace support for the Kafka components.
org.springframework.integration.kafka.dsl - package org.springframework.integration.kafka.dsl
Provides Kafka Components support for Spring Integration Java DSL.
org.springframework.integration.kafka.inbound - package org.springframework.integration.kafka.inbound
Provides inbound Spring Integration Kafka components.
org.springframework.integration.kafka.outbound - package org.springframework.integration.kafka.outbound
Provides outbound Spring Integration Kafka components.
org.springframework.integration.kafka.support - package org.springframework.integration.kafka.support
Provides support classes.
org.springframework.integration.leader - package org.springframework.integration.leader
Temporary package until s-c-c-core is released.
org.springframework.integration.leader.event - package org.springframework.integration.leader.event
Temporary package until s-c-c-core is released.
org.springframework.integration.mail - package org.springframework.integration.mail
Base package for Mail support.
org.springframework.integration.mail.config - package org.springframework.integration.mail.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.mail.dsl - package org.springframework.integration.mail.dsl
Provides Mail Components for the Java DSL.
org.springframework.integration.mail.event - package org.springframework.integration.mail.event
Events generated by the mail module
org.springframework.integration.mail.support - package org.springframework.integration.mail.support
Provides classes to support email.
org.springframework.integration.mail.transformer - package org.springframework.integration.mail.transformer
Provides classes related to transforming mail messages.
org.springframework.integration.mapping - package org.springframework.integration.mapping
Provides classes related to mapping to/from message headers.
org.springframework.integration.mapping.support - package org.springframework.integration.mapping.support
Support classes for mapping.
org.springframework.integration.message - package org.springframework.integration.message
Provides concrete Message implementations.
org.springframework.integration.metadata - package org.springframework.integration.metadata
Provides classes supporting metadata stores.
org.springframework.integration.mongodb.config - package org.springframework.integration.mongodb.config
Contains parser classes for the MongoDb namespace support.
org.springframework.integration.mongodb.dsl - package org.springframework.integration.mongodb.dsl
Provides MongoDB Components support for Java DSL.
org.springframework.integration.mongodb.inbound - package org.springframework.integration.mongodb.inbound
Provides classes related to the Mongo inbound channel adapters
org.springframework.integration.mongodb.metadata - package org.springframework.integration.mongodb.metadata
Contains mongodb metadata store related classes
org.springframework.integration.mongodb.outbound - package org.springframework.integration.mongodb.outbound
Provides classes related to the Mongo outbound channel adapters
org.springframework.integration.mongodb.store - package org.springframework.integration.mongodb.store
Provides classes related to the MongoDB message store.
org.springframework.integration.mongodb.support - package org.springframework.integration.mongodb.support
Provides supporting classes for this module.
org.springframework.integration.monitor - package org.springframework.integration.monitor
Provides classes related to Spring Integration managed resources.
org.springframework.integration.mqtt.config.xml - package org.springframework.integration.mqtt.config.xml
Provides parser classes to provide Xml namespace support for the MqttAdapter components.
org.springframework.integration.mqtt.core - package org.springframework.integration.mqtt.core
Provides core classes of the MqttAdapter module.
org.springframework.integration.mqtt.event - package org.springframework.integration.mqtt.event
ApplicationEvents generated by the mqtt module.
org.springframework.integration.mqtt.inbound - package org.springframework.integration.mqtt.inbound
Provides inbound Spring Integration MqttAdapter components.
org.springframework.integration.mqtt.outbound - package org.springframework.integration.mqtt.outbound
Provides Spring Integration components for doing outbound operations.
org.springframework.integration.mqtt.support - package org.springframework.integration.mqtt.support
Provides various support classes used across Spring Integration MqttAdapter Components.
org.springframework.integration.r2dbc.dsl - package org.springframework.integration.r2dbc.dsl
Provides classes for supporting Java DSL for R2DBC components.
org.springframework.integration.r2dbc.inbound - package org.springframework.integration.r2dbc.inbound
Provides classes for supporting R2DBC inbound components.
org.springframework.integration.r2dbc.outbound - package org.springframework.integration.r2dbc.outbound
Provides classes for supporting R2DBC outbound components.
org.springframework.integration.redis.channel - package org.springframework.integration.redis.channel
Provides classes related to Redis-backed channels.
org.springframework.integration.redis.config - package org.springframework.integration.redis.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.redis.event - package org.springframework.integration.redis.event
Events generated by the redis module
org.springframework.integration.redis.inbound - package org.springframework.integration.redis.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.redis.metadata - package org.springframework.integration.redis.metadata
Provides support for Redis-based MetadataStores.
org.springframework.integration.redis.outbound - package org.springframework.integration.redis.outbound
Provides classes supporting outbound endpoints.
org.springframework.integration.redis.store - package org.springframework.integration.redis.store
Provides classes related to the Redis message store.
org.springframework.integration.redis.support - package org.springframework.integration.redis.support
Provides supporting classes for this module.
org.springframework.integration.redis.util - package org.springframework.integration.redis.util
Provides utility classes.
org.springframework.integration.resource - package org.springframework.integration.resource
Provides classes related to messaging using Spring Resources
org.springframework.integration.rmi - package org.springframework.integration.rmi
Base package for RMI support.
org.springframework.integration.rmi.config - package org.springframework.integration.rmi.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.router - package org.springframework.integration.router
Provides classes supporting the router pattern.
org.springframework.integration.routingslip - package org.springframework.integration.routingslip
Provides classes supporting the RoutingSlip pattern.
org.springframework.integration.rsocket - package org.springframework.integration.rsocket
Provides common classes for RSocket components.
org.springframework.integration.rsocket.config - package org.springframework.integration.rsocket.config
Provides classes for RSocket XML namespace parsing and configuration support.
org.springframework.integration.rsocket.dsl - package org.springframework.integration.rsocket.dsl
Provides RSocket Components support for Spring Integration Java DSL.
org.springframework.integration.rsocket.inbound - package org.springframework.integration.rsocket.inbound
Provides classes representing inbound RSocket components.
org.springframework.integration.rsocket.outbound - package org.springframework.integration.rsocket.outbound
Provides classes representing outbound RSocket components.
org.springframework.integration.scattergather - package org.springframework.integration.scattergather
Provides classes supporting the Scatter-Gather pattern.
org.springframework.integration.scheduling - package org.springframework.integration.scheduling
Provides classes related to task scheduling.
org.springframework.integration.scripting - package org.springframework.integration.scripting
Base package for scripting support.
org.springframework.integration.scripting.config - package org.springframework.integration.scripting.config
Base package supporting configuration.
org.springframework.integration.scripting.config.jsr223 - package org.springframework.integration.scripting.config.jsr223
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.scripting.dsl - package org.springframework.integration.scripting.dsl
Provides Scripting Components support for Spring Integration Java DSL.
org.springframework.integration.scripting.jsr223 - package org.springframework.integration.scripting.jsr223
Provides classes supporting JSR223 Scripting.
org.springframework.integration.security.channel - package org.springframework.integration.security.channel
Provides classes related to secured channels.
org.springframework.integration.security.config - package org.springframework.integration.security.config
Provides classes for configuration - parsers, namespace handlers, bean post processors.
org.springframework.integration.selector - package org.springframework.integration.selector
Provides classes related to message selection.
org.springframework.integration.sftp.config - package org.springframework.integration.sftp.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.sftp.dsl - package org.springframework.integration.sftp.dsl
Provides SFTP Components for the Java DSL.
org.springframework.integration.sftp.filters - package org.springframework.integration.sftp.filters
Provides classes supporting SFTP file filtering.
org.springframework.integration.sftp.gateway - package org.springframework.integration.sftp.gateway
Provides classes supporting SFTP gateways.
org.springframework.integration.sftp.inbound - package org.springframework.integration.sftp.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.sftp.outbound - package org.springframework.integration.sftp.outbound
Provides classes for the SFTP outbound channel adapter.
org.springframework.integration.sftp.server - package org.springframework.integration.sftp.server
Provides classes related to SFTP servers.
org.springframework.integration.sftp.session - package org.springframework.integration.sftp.session
Provides classes supporting SFTP sessions.
org.springframework.integration.sftp.support - package org.springframework.integration.sftp.support
Provides general support classes for sftp.
org.springframework.integration.splitter - package org.springframework.integration.splitter
Provides classes supporting the splitter pattern.
org.springframework.integration.stomp - package org.springframework.integration.stomp
Provides core classes STOMP components.
org.springframework.integration.stomp.config - package org.springframework.integration.stomp.config
Contains parser classes for the STOMP namespace support.
org.springframework.integration.stomp.event - package org.springframework.integration.stomp.event
 
org.springframework.integration.stomp.inbound - package org.springframework.integration.stomp.inbound
Provides classes which represent inbound STOMP components.
org.springframework.integration.stomp.outbound - package org.springframework.integration.stomp.outbound
Provides classes which represent outbound STOMP components.
org.springframework.integration.stomp.support - package org.springframework.integration.stomp.support
Provides classes to support STOMP components.
org.springframework.integration.store - package org.springframework.integration.store
Provides classes releated to storing messages.
org.springframework.integration.stream - package org.springframework.integration.stream
Base package for stream support.
org.springframework.integration.stream.config - package org.springframework.integration.stream.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.support - package org.springframework.integration.support
Base core support package.
org.springframework.integration.support.channel - package org.springframework.integration.support.channel
 
org.springframework.integration.support.context - package org.springframework.integration.support.context
Provides classes supporting use of the application context.
org.springframework.integration.support.converter - package org.springframework.integration.support.converter
Provides classes supporting message conversion.
org.springframework.integration.support.json - package org.springframework.integration.support.json
Provides classes supporting json.
org.springframework.integration.support.leader - package org.springframework.integration.support.leader
 
org.springframework.integration.support.locks - package org.springframework.integration.support.locks
Provides classes related to locking resources.
org.springframework.integration.support.management - package org.springframework.integration.support.management
Provides classes related to management support.
org.springframework.integration.support.management.metrics - package org.springframework.integration.support.management.metrics
Provides interfaces related to 5.0 metrics.
org.springframework.integration.support.management.micrometer - package org.springframework.integration.support.management.micrometer
Provides classes to support the use of Micrometer for metrics.
org.springframework.integration.support.utils - package org.springframework.integration.support.utils
Provides global utility support classes for the runtime system.
org.springframework.integration.syslog - package org.springframework.integration.syslog
Base package for Syslog Support.
org.springframework.integration.syslog.config - package org.springframework.integration.syslog.config
Provides classes for configuration - parsers, namespace handlers, factory beans.
org.springframework.integration.syslog.inbound - package org.springframework.integration.syslog.inbound
Provides classes for inbound endpoints.
org.springframework.integration.test.condition - package org.springframework.integration.test.condition
 
org.springframework.integration.test.context - package org.springframework.integration.test.context
Test context-related components.
org.springframework.integration.test.mail - package org.springframework.integration.test.mail
Provides testing utils for mail support.
org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
Provides several BaseMatcher implementations.
org.springframework.integration.test.mock - package org.springframework.integration.test.mock
Utilities for mocking integration components.
org.springframework.integration.test.predicate - package org.springframework.integration.test.predicate
 
org.springframework.integration.test.rule - package org.springframework.integration.test.rule
Provides various test rules.
org.springframework.integration.test.support - package org.springframework.integration.test.support
Provides several test support classes including for testing Spring Integration request-response message scenarios.
org.springframework.integration.test.util - package org.springframework.integration.test.util
Provides various test utilities, for example TestUtils provides convenience helpers to easily retrieve private bean properties.
org.springframework.integration.transaction - package org.springframework.integration.transaction
Provides classes supporting the use of transactions and pseudo transactions in Spring Integration applications.
org.springframework.integration.transformer - package org.springframework.integration.transformer
Contains core-implementation of various Transformers which includes Enrichers and Filters.
org.springframework.integration.transformer.support - package org.springframework.integration.transformer.support
Contains support classes for Transformers.
org.springframework.integration.util - package org.springframework.integration.util
Provides core utility classes.
org.springframework.integration.webflux.config - package org.springframework.integration.webflux.config
Provides classes for configuration - parsers, namespace handlers.
org.springframework.integration.webflux.dsl - package org.springframework.integration.webflux.dsl
Provides WebFlux Components support for Spring Integration Java DSL.
org.springframework.integration.webflux.inbound - package org.springframework.integration.webflux.inbound
Provides classes supporting inbound endpoints.
org.springframework.integration.webflux.outbound - package org.springframework.integration.webflux.outbound
Provides classes supporting outbound endpoints.
org.springframework.integration.webflux.support - package org.springframework.integration.webflux.support
Provides classes to support WebFlux endpoints.
org.springframework.integration.websocket - package org.springframework.integration.websocket
Provides classes used across all WebSocket components.
org.springframework.integration.websocket.config - package org.springframework.integration.websocket.config
Contains parser classes for the WebSockets namespace support.
org.springframework.integration.websocket.event - package org.springframework.integration.websocket.event
 
org.springframework.integration.websocket.inbound - package org.springframework.integration.websocket.inbound
Provides classes which represent inbound WebSocket components.
org.springframework.integration.websocket.outbound - package org.springframework.integration.websocket.outbound
Provides classes which represent outbound WebSocket components.
org.springframework.integration.websocket.support - package org.springframework.integration.websocket.support
Provides support classes used from WebSocket components.
org.springframework.integration.ws - package org.springframework.integration.ws
Provides several inbound and outbound Web Service components.
org.springframework.integration.ws.config - package org.springframework.integration.ws.config
Contains parser classes for the Web Services namespace support.
org.springframework.integration.ws.dsl - package org.springframework.integration.ws.dsl
Contains classes for DSL support.
org.springframework.integration.xml - package org.springframework.integration.xml
Root package of the XML Module.
org.springframework.integration.xml.config - package org.springframework.integration.xml.config
Contains parser classes for the XML namespace support.
org.springframework.integration.xml.result - package org.springframework.integration.xml.result
Provides ResultFactory that will return Result, possibly taking into account payload instance.
org.springframework.integration.xml.router - package org.springframework.integration.xml.router
Provides XML message routers.
org.springframework.integration.xml.selector - package org.springframework.integration.xml.selector
Provides XML-centric MessageSelector implementations.
org.springframework.integration.xml.source - package org.springframework.integration.xml.source
Provides various SourceFactory implementations.
org.springframework.integration.xml.splitter - package org.springframework.integration.xml.splitter
Provides implementations of AbstractMessageSplitter.
org.springframework.integration.xml.transformer - package org.springframework.integration.xml.transformer
Provides Transformer and Enricher implementations.
org.springframework.integration.xml.transformer.support - package org.springframework.integration.xml.transformer.support
Contains support classes for Transformers.
org.springframework.integration.xml.xpath - package org.springframework.integration.xml.xpath
Provides XPath supporting classes.
org.springframework.integration.xmpp - package org.springframework.integration.xmpp
Root package of the Spring Integration XMPP Module.
org.springframework.integration.xmpp.config - package org.springframework.integration.xmpp.config
Contains parser classes for the XMPP namespace support.
org.springframework.integration.xmpp.core - package org.springframework.integration.xmpp.core
Provides classes shared across all XMPP components.
org.springframework.integration.xmpp.inbound - package org.springframework.integration.xmpp.inbound
Provides XMPP inbound Endpoint implementations that extend AbstractXmppConnectionAwareEndpoint.
org.springframework.integration.xmpp.outbound - package org.springframework.integration.xmpp.outbound
Provides XMPP outbound MessageHandler implementations.
org.springframework.integration.xmpp.support - package org.springframework.integration.xmpp.support
Provides XMPP specific support classes.
org.springframework.integration.zeromq - package org.springframework.integration.zeromq
Provides common classes for supporting ZeroMQ components.
org.springframework.integration.zeromq.channel - package org.springframework.integration.zeromq.channel
Provides classes for message channels support over ZeroMQ.
org.springframework.integration.zeromq.dsl - package org.springframework.integration.zeromq.dsl
Provides classes for supporting ZeroMQ component via Java DSL.
org.springframework.integration.zeromq.inbound - package org.springframework.integration.zeromq.inbound
Provides classes for inbound channel adapters over ZeroMQ.
org.springframework.integration.zeromq.outbound - package org.springframework.integration.zeromq.outbound
Provides classes for outbound channel adapters over ZeroMQ.
org.springframework.integration.zookeeper.config - package org.springframework.integration.zookeeper.config
 
org.springframework.integration.zookeeper.config.xml - package org.springframework.integration.zookeeper.config.xml
Base package for zookeeper configuration.
org.springframework.integration.zookeeper.leader - package org.springframework.integration.zookeeper.leader
Temporary package until s-c-c-zookeeper is released.
org.springframework.integration.zookeeper.lock - package org.springframework.integration.zookeeper.lock
Provides classes related to locking.
org.springframework.integration.zookeeper.metadata - package org.springframework.integration.zookeeper.metadata
Provides classes supporting the Zookeeper-based ListenableMetadataStore
origin(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
List of allowed origins, e.g.
ORIGINAL_FILE - Static variable in class org.springframework.integration.file.FileHeaders
 
OSDelegatingFileTailingMessageProducer - Class in org.springframework.integration.file.tail
A file tailing message producer that delegates to the OS tail program.
OSDelegatingFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
outboundAdapter(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
Create an initial AmqpOutboundEndpointSpec (adapter).
outboundAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the one-way FileWritingMessageHandler.
outboundAdapter(String) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the one-way FileWritingMessageHandler.
outboundAdapter(Expression) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the one-way FileWritingMessageHandler.
outboundAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the one-way FileWritingMessageHandler.
outboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(SessionFactory<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(RemoteFileTemplate<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
outboundAdapter(RemoteFileTemplate<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
outboundAdapter(FtpRemoteFileTemplate) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(FtpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
A FtpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an outbound gateway using the supplied connection factory.
outboundAdapter(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an outbound gateway using the supplied connection factory.
outboundAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound unicast channel adapter using the supplied host and port.
outboundAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound unicast channel adapter using the supplied destination expression.
outboundAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound unicast channel adapter using the supplied destination expression.
outboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsOutboundChannelAdapterSpec.
outboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsOutboundChannelAdapterSpec.
outboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for one-way adapter based on the provided EntityManagerFactory.
outboundAdapter(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for one-way adapter based on the provided EntityManager.
outboundAdapter(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for one-way adapter based on the provided JpaOperations.
outboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
outboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
A MailSendingMessageHandlerSpec factory based on provide host.
outboundAdapter(MailSender) - Static method in class org.springframework.integration.mail.dsl.Mail
A convenient factory method to produce MailSendingMessageHandler based on provided MailSender.
outboundAdapter(SessionFactory<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(SessionFactory<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
outboundAdapter(SftpRemoteFileTemplate) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundAdapter(SftpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
An SftpMessageHandlerSpec factory for an outbound channel adapter spec.
outboundChannelAdapter(URI) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided URI.
outboundChannelAdapter(String) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided uri.
outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided Function to evaluate target uri against request message.
outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided SpEL Expression to evaluate target uri against request message.
outboundChannelAdapter(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided URI and RestTemplate.
outboundChannelAdapter(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided uri and RestTemplate.
outboundChannelAdapter(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided Function to evaluate target uri against request message and RestTemplate for HTTP exchanges.
outboundChannelAdapter(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for one-way adapter based on provided SpEL Expression to evaluate target uri against request message and RestTemplate for HTTP exchanges.
outboundChannelAdapter(KafkaTemplate<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaProducerMessageHandlerSpec with ProducerFactory.
outboundChannelAdapter(R2dbcEntityOperations) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
Create an instance of R2dbcMessageHandlerSpec for the provided R2dbcEntityOperations.
outboundChannelAdapter(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided URI.
outboundChannelAdapter(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided uri.
outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided Function to evaluate target uri against request message.
outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided SpEL Expression to evaluate target uri against request message.
outboundChannelAdapter(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided URI and WebClient.
outboundChannelAdapter(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided uri and WebClient.
outboundChannelAdapter(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided Function to evaluate target uri against request message and WebClient for HTTP exchanges.
outboundChannelAdapter(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for one-way adapter based on provided SpEL Expression to evaluate target uri against request message and WebClient for HTTP exchanges.
outboundChannelAdapter(ZContext, String) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqMessageHandlerSpec for the provided ZContext and connection URL.
outboundChannelAdapter(ZContext, String, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqMessageHandlerSpec for the provided ZContext, connection URL and SocketType.
outboundGateway(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
Create an initial AmqpOutboundEndpointSpec (gateway).
outboundGateway(File) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the gateway FileWritingMessageHandler.
outboundGateway(String) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the gateway FileWritingMessageHandler.
outboundGateway(Expression) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec based on the provided Expression for directory.
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileWritingMessageHandlerSpec builder for the gateway FileWritingMessageHandler.
outboundGateway(SessionFactory<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
Produce a FtpOutboundGatewaySpec based on the SessionFactory, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
Produce a FtpOutboundGatewaySpec based on the SessionFactory, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
Produce a FtpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
Produce a FtpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
outboundGateway(URI) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided URI.
outboundGateway(String) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided uri.
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided Function to evaluate target uri against request message.
outboundGateway(Expression) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided SpEL Expression to evaluate target uri against request message.
outboundGateway(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided URI and RestTemplate.
outboundGateway(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided uri and RestTemplate.
outboundGateway(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided Function to evaluate target uri against request message and RestTemplate for HTTP exchanges.
outboundGateway(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
Create an HttpMessageHandlerSpec builder for request-reply gateway based on provided SpEL Expression to evaluate target uri against request message and RestTemplate for HTTP exchanges.
outboundGateway(AbstractClientConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an outbound gateway using the supplied client connection factory.
outboundGateway(TcpClientConnectionFactorySpec) - Static method in class org.springframework.integration.ip.dsl.Tcp
Create an outbound gateway using the supplied client connection factory.
outboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsOutboundGatewaySpec.
outboundGateway(ReplyingKafkaTemplate<K, V, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
outboundGateway(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaProducerMessageHandlerSpec with ProducerFactory.
outboundGateway(MongoDatabaseFactory, MongoConverter) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a MongoDbOutboundGatewaySpec builder instance based on the provided MongoDatabaseFactory and MongoConverter.
outboundGateway(MongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a MongoDbOutboundGatewaySpec builder instance based on the provided MongoOperations.
outboundGateway(String, Object...) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
Create an RSocketOutboundGatewaySpec builder for request-reply gateway based on provided route and optional variables to expand route template.
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
Create an RSocketOutboundGatewaySpec builder for request-reply gateway based on provided Function to evaluate target route against request message.
outboundGateway(Expression) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
Create an RSocketOutboundGatewaySpec builder for request-reply gateway based on provided SpEL Expression to evaluate target route against request message.
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
Produce a SftpOutboundGatewaySpec based on the SessionFactory, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
Produce a SftpOutboundGatewaySpec based on the SessionFactory, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
Produce a SftpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
Produce a SftpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
outboundGateway(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided URI.
outboundGateway(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided uri.
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided Function to evaluate target uri against request message.
outboundGateway(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided SpEL Expression to evaluate target uri against request message.
outboundGateway(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided URI and WebClient.
outboundGateway(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided uri and WebClient.
outboundGateway(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided Function to evaluate target uri against request message and WebClient for HTTP exchanges.
outboundGateway(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
Create an WebFluxMessageHandlerSpec builder for request-reply gateway based on provided SpEL Expression to evaluate target uri against request message and WebClient for HTTP exchanges.
OutboundGatewayType - Enum in org.springframework.integration.jpa.support
Indicates the mode of operation for the outbound Jpa 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.
outboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Factory method for creating a basic outbound mapper instance.
OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
Strategy interface for mapping from a Message to an Object.
outboundMulticastAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound multicast channel adapter using the supplied host and port.
outboundMulticastAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound multicast channel adapter using the supplied destination expression.
outboundMulticastAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
Create an outbound multicast channel adapter using the supplied destination expression.
outboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
outboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Specify the outputChannel for the MessageProducer
outputChannel(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Specify the bean name of the outputChannel for the MessageProducer
outputChannel(MessageChannel) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
outputExpression(String) - Method in class org.springframework.integration.dsl.AggregatorSpec
An expression to determine the output message from the released group.
outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.AggregatorSpec
A processor to determine the output message from the released group.
outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.BarrierSpec
 

P

PACKET_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The remote address for a UDP packet.
parameter(Object) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Add a value for indexed query parameter.
parameter(String, Object) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Add a value for named parameter in the query.
parameter(JpaParameter) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
 
parameterExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Add a SpEL expression for indexed parameter in the query.
parameterExpression(String, String) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Add a SpEL expression for named parameter in the query.
parameterSource(ParameterSource) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify a ParameterSource that would be used to provide additional parameters.
ParameterSource - Interface in org.springframework.integration.jpa.support.parametersource
 
parameterSourceFactory(ParameterSourceFactory) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify a ParameterSourceFactory to populate query parameters at runtime against request message.
ParameterSourceFactory - Interface in org.springframework.integration.jpa.support.parametersource
 
params(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
The parameters of the mapped request, narrowing the primary mapping.
parse(Map<String, Object>) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AnnotationConfigParser
 
parse(Element, ParserContext) - Method in interface org.springframework.integration.config.xml.BeanDefinitionRegisteringParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GatewayParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.WireTapParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.http.config.IntegrationGraphControllerParser
 
parse(String, int, boolean) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser
 
parseAcknowledgeMode(String) - Static method in class org.springframework.integration.jms.util.JmsAdapterUtils
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this method to return the BeanDefinition for the MessageConsumer.
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.LoggingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.gemfire.config.xml.GemfireOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.mail.config.MailOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.mongodb.config.MongoDbOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisQueueOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisStoreOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.stomp.config.StompOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.stream.config.ConsoleOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.websocket.config.WebSocketOutboundMessageHandlerParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
Parse the MessageHandler.
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AggregatorParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.BarrierParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.BridgeParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ControlBusParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DelayerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.EnricherParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ResequencerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ScatterGatherParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileSplitterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.groovy.config.GroovyControlBusParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jpa.config.xml.RetrievingJpaOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jpa.config.xml.UpdatingJpaOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.mongodb.config.MongoDbOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathFilterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
parseInnerHandlerDefinition(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
parseInt(int) - Static method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
parseInterceptors(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ConverterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishingInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RetryAdviceParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.TransactionSynchronizationFactoryParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcMessageStoreParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.zookeeper.config.xml.LeaderListenerParser
 
PARSER - Static variable in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
PARSER - Static variable in class org.springframework.integration.dsl.GatewayProxySpec
 
PARSER - Static variable in class org.springframework.integration.dsl.IntegrationComponentSpec
 
PARSER - Static variable in class org.springframework.integration.support.MapBuilder
 
parseRemoteFileTemplate(Element, ParserContext, boolean, Class<? extends RemoteFileOperations<?>>) - Static method in class org.springframework.integration.file.config.FileParserUtils
 
parseReturnVariable(String) - Static method in class org.springframework.integration.scripting.jsr223.PythonScriptExecutor.PythonVariableParser
 
parseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
Subclasses must implement this method to parse the PollableSource instance which the created Channel Adapter will poll.
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.feed.config.FeedInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jpa.config.xml.JpaInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.mail.config.MailInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.mongodb.config.MongoDbInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisStoreInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.stream.config.ConsoleInboundChannelAdapterParser
 
parseStructuredDataElements(RFC5424SyslogParser.Reader) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser
Default implementation returns a list of structured data elements with no internal parsing.
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.mail.config.MailToStringTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.MarshallingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.UnmarshallingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XsltPayloadTransformerParser
 
parseUrl(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseUrl(Element, ParserContext) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
Deprecated.
 
parseWithHeaders(JsonParser, String, Map<String, Object>) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
PartialSuccessException - Exception in org.springframework.integration.support
A MessagingException thrown when a non-transactional operation is performing multiple updates from a single message, e.g.
PartialSuccessException(Message<?>, String, Throwable, Collection<?>, Collection<?>) - Constructor for exception org.springframework.integration.support.PartialSuccessException
 
partitionId(Integer) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a partitionId of Kafka topic.
partitionId(Function<Message<P>, Integer>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at runtime to determine the partition id under which a message will be stored in the topic.
partitionIdExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the topic partitionId at runtime against request Message as a root object of evaluation context.
partitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the topic partitionId at runtime against request Message as a root object of evaluation context.
PASSCODE - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
PassThroughTransactionSynchronizationFactory - Class in org.springframework.integration.transaction
PassThroughTransactionSynchronizationFactory() - Constructor for class org.springframework.integration.transaction.PassThroughTransactionSynchronizationFactory
 
PassThruLockRegistry - Class in org.springframework.integration.support.locks
The LockRegistry implementation which has no effect.
PassThruLockRegistry() - Constructor for class org.springframework.integration.support.locks.PassThruLockRegistry
 
PassThruMessageConverter - Class in org.springframework.integration.support.converter
The simple MessageConverter implementation which contract is to return Message as is for both from/to operations.
PassThruMessageConverter() - Constructor for class org.springframework.integration.support.converter.PassThruMessageConverter
 
PassThruSubProtocolHandler - Class in org.springframework.integration.websocket.support
The simple 'pass thru' SubProtocolHandler, when there is no interests in the WebSocket sub-protocols.
PassThruSubProtocolHandler() - Constructor for class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
password(String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the mail user password.
pathFor(String) - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
Return the path for the key.
PathMovedEvent - Class in org.springframework.integration.ftp.server
An event emitted when a path is moved.
PathMovedEvent(FtpSession, FtpRequest) - Constructor for class org.springframework.integration.ftp.server.PathMovedEvent
 
PathMovedEvent - Class in org.springframework.integration.sftp.server
An event emitted when a path is moved.
PathMovedEvent(Object, Path, Path, Throwable) - Constructor for class org.springframework.integration.sftp.server.PathMovedEvent
 
PathRemovedEvent - Class in org.springframework.integration.ftp.server
An event emitted when a file or directory is removed.
PathRemovedEvent(FtpSession, FtpRequest, boolean) - Constructor for class org.springframework.integration.ftp.server.PathRemovedEvent
 
PathRemovedEvent - Class in org.springframework.integration.sftp.server
An event emitted when a file or directory is removed.
PathRemovedEvent(Object, Path, boolean, Throwable) - Constructor for class org.springframework.integration.sftp.server.PathRemovedEvent
 
PatternBasedHeaderMatcher(Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
patternFileNameFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a simple pattern to match remote files (e.g.
patternFileNameFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
 
patternFileNameFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
 
patternFilter(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
patternFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a simple pattern filter (e.g.
patternFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Configure a simple pattern filter (e.g.
patternFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
Specify a simple pattern to match remote files.
patternFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
Specify a simple pattern to match remote files (e.g.
patternFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
 
patternFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
Specify a simple pattern to match remote files (e.g.
PatternMatchUtils - Class in org.springframework.integration.support.utils
Utility methods for pattern matching.
patternMputFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
A SimplePatternFileListFilter that runs against the local file system view when using MPUT command.
Pausable - Interface in org.springframework.integration.core
Endpoints implementing this interface can be paused/resumed.
pause() - Method in interface org.springframework.integration.core.Pausable
Pause the endpoint.
pause() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
pause() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
pause() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
PayloadAndHeaderMatcher<T> - Class in org.springframework.integration.test.matcher
Matcher to make assertions about message equality easier.
PayloadDeserializingTransformer - Class in org.springframework.integration.transformer
Transformer that deserializes the inbound byte array payload to an object by delegating to a Converter<byte[], Object>.
PayloadDeserializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadDeserializingTransformer
Instantiate based on the AllowListDeserializingConverter with the DefaultDeserializer.
PayloadDeserializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-deserializing-transformer' element.
PayloadDeserializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
payloadExpression(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
An expression that will be used to generate the payload for all methods in the service interface unless explicitly overridden by a method declaration.
payloadExpression(Expression) - Method in class org.springframework.integration.dsl.GatewayProxySpec
An expression that will be used to generate the payload for all methods in the service interface unless explicitly overridden by a method declaration.
payloadExpression(String) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a SpEL expression to evaluate in order to generate the Message payload.
payloadExpression(Expression) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a SpEL expression to evaluate in order to generate the Message payload.
PayloadExpressionArgumentResolver - Class in org.springframework.integration.handler.support
The HandlerMethodArgumentResolver for evaluating Payload.expression() as a SpEL expression against message and converting result to expected parameter type.
PayloadExpressionArgumentResolver() - Constructor for class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
 
payloadFunction(Function<MethodArgsHolder, ?>) - Method in class org.springframework.integration.dsl.GatewayProxySpec
A Function that will be used to generate the payload for all methods in the service interface unless explicitly overridden by a method declaration.
payloadFunction(Function<HttpEntity<P>, ?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a Function to evaluate in order to generate the Message payload.
PayloadMatcher<T> - Class in org.springframework.integration.test.matcher
Is the payload of a Message equal to a given value or is matching a given matcher?
Payloads - Annotation Type in org.springframework.integration.annotation
This annotation marks a method parameter as being a list of message payloads, for POJO handlers that deal with lists of messages (e.g.
PayloadsArgumentResolver - Class in org.springframework.integration.handler.support
The HandlerMethodArgumentResolver for resolving a Collection of payloads or expression against each payload.
PayloadsArgumentResolver() - Constructor for class org.springframework.integration.handler.support.PayloadsArgumentResolver
 
PayloadSerializingTransformer - Class in org.springframework.integration.transformer
Transformer that serializes the inbound payload into a byte array by delegating to a Converter<Object, byte[]>.
PayloadSerializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadSerializingTransformer
Instantiate based on the SerializingConverter with the DefaultSerializer.
PayloadSerializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-serializing-transformer' element.
PayloadSerializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
payloadType(Class<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
Set the payload type.
payloadType(Class<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
When using a type-aware message converter (such as StringJsonMessageConverter, set the payload type the converter should create.
payloadType(Class<?>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
Set the expected payload type.
payloadType - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
PayloadTypeConvertingTransformer<T,U> - Class in org.springframework.integration.transformer
Transformer that converts the inbound payload to an object by delegating to a Converter<Object, Object>.
PayloadTypeConvertingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
PayloadTypeRouter - Class in org.springframework.integration.router
A Message Router that resolves the MessageChannel based on the Message's payload type.
PayloadTypeRouter() - Constructor for class org.springframework.integration.router.PayloadTypeRouter
 
PayloadTypeRouterParser - Class in org.springframework.integration.config.xml
Parser for the <payload-type-router/> element.
PayloadTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
PayloadTypeSelector - Class in org.springframework.integration.selector
A MessageSelector implementation that checks the type of the Message payload.
PayloadTypeSelector(Class<?>...) - Constructor for class org.springframework.integration.selector.PayloadTypeSelector
Create a selector for the provided types.
PayloadValidator<T> - Class in org.springframework.integration.test.support
Validate a message payload.
PayloadValidator() - Constructor for class org.springframework.integration.test.support.PayloadValidator
 
payloadWhenNull(AttributeAccessor) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Build a Throwable payload based on the provided context for future ErrorMessage when there is original Throwable.
payloadWhenNull(AttributeAccessor) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
 
peek() - Method in class org.springframework.integration.store.MessageGroupQueue
 
peek() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
performReceive(Long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
persist(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
persist(Object, int, boolean) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
persist(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Persists the entity.
persist(Object, int, boolean) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Persists the entity.
persistMode(PersistMode) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
Specify a PersistMode for the gateway.
PersistMode - Enum in org.springframework.integration.jpa.support
Indicates how entities shall be persisted to the underlying persistence store.
phase(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
PHASE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
phase(int) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
phase(int) - Method in class org.springframework.integration.dsl.EndpointSpec
 
phase(int) - Method in class org.springframework.integration.dsl.MessageProducerSpec
 
phase(int) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A lifecycle phase to use.
phase(int) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
phase(int) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
phase(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
PointToPointChannelParser - Class in org.springframework.integration.config.xml
Parser for the <channel> element.
PointToPointChannelParser() - Constructor for class org.springframework.integration.config.xml.PointToPointChannelParser
 
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.
PojoCodec - Class in org.springframework.integration.codec.kryo
Kryo Codec that can encode and decode arbitrary types.
PojoCodec() - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
 
PojoCodec(KryoRegistrar) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with a single KryoRegistrar.
PojoCodec(List<KryoRegistrar>) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with zero to many KryoRegistrars.
PojoCodec(KryoRegistrar, boolean) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with a single KryoRegistrar.
PojoCodec(List<KryoRegistrar>, boolean) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with zero to many KryoRegistrars.
poll(MessageHandler) - Method in class org.springframework.integration.endpoint.MessageSourcePollingTemplate
 
poll(MessageHandler) - Method in interface org.springframework.integration.endpoint.PollingOperations
Poll for a message.
poll() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
poll() - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute the JPA operation.
poll(Message<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute a (typically retrieving) JPA operation.
poll(long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
poll() - Method in class org.springframework.integration.store.MessageGroupQueue
 
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.
pollableChannel(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsPollableMessageChannelSpec.
pollableChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsPollableMessageChannelSpec.
pollableChannel(KafkaTemplate<?, ?>, KafkaMessageSource<?, ?>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create a spec for a pollable channel with the provided parameters.
PollableChannelNode - Class in org.springframework.integration.graph
Represents a pollable channel.
PollableChannelNode(int, String, MessageChannel) - Constructor for class org.springframework.integration.graph.PollableChannelNode
 
PollableJmsChannel - Class in org.springframework.integration.jms
 
PollableJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.PollableJmsChannel
 
PollableKafkaChannel - Class in org.springframework.integration.kafka.channel
Pollable channel backed by a Kafka topic.
PollableKafkaChannel(KafkaOperations<?, ?>, KafkaMessageSource<?, ?>) - Constructor for class org.springframework.integration.kafka.channel.PollableKafkaChannel
Construct an instance with the provided parameters.
Poller - Annotation Type in org.springframework.integration.annotation
Provides the PollerMetadata options for the Messaging annotations for polled endpoints.
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
poller(Function<PollerFactory, PollerSpec>) - Method in class org.springframework.integration.dsl.EndpointSpec
 
poller(PollerSpec) - Method in class org.springframework.integration.dsl.EndpointSpec
 
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.EndpointSpec
 
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
PollerFactory - Class in org.springframework.integration.dsl
An Adapter class for the Pollers factory.
PollerMetadata - Class in org.springframework.integration.scheduling
 
PollerMetadata() - Constructor for class org.springframework.integration.scheduling.PollerMetadata
 
PollerParser - Class in org.springframework.integration.config.xml
Parser for the <poller> element.
PollerParser() - Constructor for class org.springframework.integration.config.xml.PollerParser
 
Pollers - Class in org.springframework.integration.dsl
An utility class to provide PollerSpecs for PollerMetadata configuration variants.
PollerSpec - Class in org.springframework.integration.dsl
PollingConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a PollableChannel.
PollingConsumer(PollableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.PollingConsumer
 
PollingOperations - Interface in org.springframework.integration.endpoint
Operations to perform on some message source.
pollMessageFromGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Polls the database for a new message that is persisted for the given group id which represents the channel identifier.
pollMessageFromGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
pollMessageFromGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Polls Message from this MessageGroup (in FIFO style if supported by the implementation) while also removing the polled Message
pollMessageFromGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
PollSkipAdvice - Class in org.springframework.integration.scheduling
An advice that can be added to a poller's advice chain that determines whether a poll should be skipped or not.
PollSkipAdvice() - Constructor for class org.springframework.integration.scheduling.PollSkipAdvice
 
PollSkipAdvice(PollSkipStrategy) - Constructor for class org.springframework.integration.scheduling.PollSkipAdvice
 
PollSkipStrategy - Interface in org.springframework.integration.scheduling
Implementations determine whether a particular poll should be skipped.
pollTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the max time to block in the consumer waiting for records.
pool - Variable in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
Pool<T> - Interface in org.springframework.integration.util
Represents a pool of items.
PoolItemNotAvailableException - Exception in org.springframework.integration.util
Thrown when a pooled item could not be obtained for some reason.
PoolItemNotAvailableException(String, Throwable) - Constructor for exception org.springframework.integration.util.PoolItemNotAvailableException
 
PoolItemNotAvailableException(String) - Constructor for exception org.springframework.integration.util.PoolItemNotAvailableException
 
poolSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
pop3(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
pop3InboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
pop3InboundAdapter(Pop3MailReceiver) - Static method in class org.springframework.integration.mail.dsl.Mail
A Pop3MailInboundChannelAdapterSpec factory based on the provided Pop3MailReceiver.
pop3InboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
A Pop3MailInboundChannelAdapterSpec factory based on the provided url.
pop3InboundAdapter(String, String, String) - Static method in class org.springframework.integration.mail.dsl.Mail
A Pop3MailInboundChannelAdapterSpec factory based on the provided host, user, password and the default port.
pop3InboundAdapter(String, int, String, String) - Static method in class org.springframework.integration.mail.dsl.Mail
A Pop3MailInboundChannelAdapterSpec factory based on the provided host, port, user, and password.
Pop3MailInboundChannelAdapterSpec - Class in org.springframework.integration.mail.dsl
Pop3MailInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.mail.dsl.Pop3MailInboundChannelAdapterSpec
 
Pop3MailInboundChannelAdapterSpec(Pop3MailReceiver) - Constructor for class org.springframework.integration.mail.dsl.Pop3MailInboundChannelAdapterSpec
 
Pop3MailInboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.mail.dsl.Pop3MailInboundChannelAdapterSpec
 
Pop3MailInboundChannelAdapterSpec(String, String, String) - Constructor for class org.springframework.integration.mail.dsl.Pop3MailInboundChannelAdapterSpec
 
Pop3MailInboundChannelAdapterSpec(String, int, String, String) - Constructor for class org.springframework.integration.mail.dsl.Pop3MailInboundChannelAdapterSpec
 
Pop3MailReceiver - Class in org.springframework.integration.mail
A MailReceiver implementation that polls a mail server using the POP3 protocol.
Pop3MailReceiver() - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String, String, String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String, int, String, String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
popSequence(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Perform a MessageBuilder.popSequenceDetails() for output message or not.
popSequenceDetails() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
popSequenceDetails() - Method in class org.springframework.integration.support.MessageBuilder
 
populateJavaTypes(Map<String, Object>, Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
populatePropagatedContext(S, Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
populatePropagatedContext(Authentication, Message<?>, MessageChannel) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
 
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.
populateStandardHeaders(Map<String, Object>, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Populate the specified standard headers to the specified source.
populateStandardHeaders(Map<String, Object>, Map<String, Object>, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Populate the specified standard headers to the specified source.
populateStandardHeaders(Map<String, Object>, SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
populateStandardHeaders(Map<String, Object>, Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
populateUserDefinedHeader(String, Object, MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
populateUserDefinedHeader(String, Object, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Populate the specified user-defined headers to the specified source.
populateUserDefinedHeader(String, Object, SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
populateUserDefinedHeader(String, Object, Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
PORT - Static variable in class org.springframework.integration.ip.IpHeaders
The remote port for a UDP packet.
port(int) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the port.
PositionSupportingParameterSource - Interface in org.springframework.integration.jpa.support.parametersource
 
PostgresChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
PostgresChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
postProcess(Object, String, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
postProcess(Object, String, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
postProcess(Object, String, Method, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultRouterParser
 
postProcess(Message<?>, Object) - Method in class org.springframework.integration.filter.MessageFilter
 
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
postProcess(Message<?>, Object) - Method in interface org.springframework.integration.handler.PostProcessingMessageHandler
Take some further action on the result and/or message.
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
Subclasses may override this no-op method to provide additional configuration.
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
postProcess(Object, ScriptEngine, String, Bindings) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
Subclasses may implement this to provide any special handling required
postProcess(Object, ScriptEngine, String, Bindings) - Method in class org.springframework.integration.scripting.jsr223.DefaultScriptExecutor
 
postProcess(Object, ScriptEngine, String, Bindings) - Method in class org.springframework.integration.scripting.jsr223.KotlinScriptExecutor
 
postProcess(Object, ScriptEngine, String, Bindings) - Method in class org.springframework.integration.scripting.jsr223.PythonScriptExecutor
 
postProcess(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
postProcess(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.FixedSubscriberChannelBeanFactoryPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
postProcessBeforeDestruction(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition.ReplyProducerCleaner
 
postProcessBeforeDestruction(Object, String) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
postProcessBeforeDestruction(Object, String) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
postProcessBeforeDestruction(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
postProcessBeforeDestruction(Object, String) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
 
postProcessBuilder(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
postProcessClientAfterConnect(T) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Will handle additional initialization after client.connect() method was invoked, but before any action on the client has been taken
postProcessClientAfterConnect(FTPSClient) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
postProcessClientBeforeConnect(T) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Will handle additional initialization before client.connect() method was invoked.
postProcessClientBeforeConnect(FTPSClient) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
postProcessFilter(MessageFilter) - Method in class org.springframework.integration.config.FilterFactoryBean
 
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
Subclasses may override this method for additional configuration.
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
Deprecated.
 
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
Subclasses may override this method to provide any additional processing.
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
PostProcessingMessageHandler - Interface in org.springframework.integration.handler
Implementations of this interface are subclasses of AbstractMessageHandler that perform post processing after the AbstractMessageHandler.handleMessageInternal(org.springframework.messaging.Message) call.
postProcessMessage(Message<?>) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.FilterFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
postProcessServerSocket(ServerSocket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
postProcessServerSocket(ServerSocket) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
No-Op.
postProcessServerSocket(ServerSocket) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketSupport
Performs any further modifications to the server socket after the connection factory has created the socket and set any configured attributes, before invoking ServerSocket.accept().
postProcessSocket(Socket) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
Enables host verification for SSL, if so configured.
postProcessSocket(Socket) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketSupport
Performs any further modifications to the Socket after the socket has been created by a client, or accepted by a server, and after any configured atributes have been set.
postProcessSSLEngine(SSLEngine) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
Subclasses can post-process the ssl engine (set properties).
postProcessTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
Subclasses may override this method to provide additional configuration.
postProcessTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.FileToStringTransformerParser
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
prefetchCount(int) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
prefetchCount(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
prefix(String) - Method in class org.springframework.integration.dsl.RouterSpec
PREFIX - Static variable in class org.springframework.integration.file.FileHeaders
 
prefix - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
PREFIX - Static variable in class org.springframework.integration.http.HttpHeaders
 
PREFIX - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
PREFIX - Static variable in class org.springframework.integration.mail.MailHeaders
 
PREFIX - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
PREFIX - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
A prefix for MongoDb-specific message headers.
PREFIX - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
PREFIX - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
PREFIX - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
PREFIX - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
PREFIX - Static variable in class org.springframework.integration.transformer.support.AvroHeaders
The prefix for Apache Avro specific message headers.
PREFIX - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
PREFIX - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
PREFIX - Static variable in class org.springframework.integration.zeromq.ZeroMqHeaders
 
PREFIX_CHANGE_STREAM - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
The prefix for change stream event headers.
PrefixBasedMatcher(boolean, String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
prepareRequest(HttpServletRequest) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Prepares an instance of ServletServerHttpRequest from the raw HttpServletRequest.
prepareRequestEntity(ServletServerHttpRequest) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
preReceive(MessageChannel, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
PresenceInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:presence-inbound-channel-adapter' element.
PresenceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.PresenceInboundChannelAdapterParser
 
PresenceListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
An inbound endpoint that is able to login and then emit particular Presence event occurs within the logged-in user's Roster.
PresenceListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
PresenceListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
PresenceOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:presence-outbound-channel-adapter' element
PresenceOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.PresenceOutboundChannelAdapterParser
 
PresenceSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
MessageHandler that publishes updated Presence values for a given XMPP connection.
PresenceSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
PresenceSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
preSend(Message<?>, MessageChannel, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.WireTap
Intercept the Message and, if accepted by the MessageSelector, send it to the secondary target.
preserveTimestamp(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Set to true to preserve the destination file timestamp.
preserveTimestamp(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Set to true to enable the preservation of the remote file timestamp when transferring.
preserveWireFeed(boolean) - Method in class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
 
prev() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
preventDuplicates(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Configure an AcceptOnceFileListFilter if preventDuplicates == true, otherwise - AcceptAllFileListFilter.
priority() - Method in class org.springframework.integration.dsl.Channels
 
priority(String) - Method in class org.springframework.integration.dsl.Channels
 
priority(String, PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
priority(PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
priority(Number) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
priority(Number, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
priority() - Static method in class org.springframework.integration.dsl.MessageChannels
 
priority(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
priority(PriorityCapableChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.MessageChannels
 
priority(String, PriorityCapableChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.MessageChannels
 
PRIORITY - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
priority(int) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
Default priority.
priority(int) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Default priority.
priority(int) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
May be overridden at run time by the message priority header.
PRIORITY - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
PriorityCapableChannelMessageStore - Interface in org.springframework.integration.store
A ChannelMessageStore that supports the notion of message priority.
PriorityChannel - Class in org.springframework.integration.channel
A message channel that prioritizes messages based on a Comparator.
PriorityChannel() - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
PriorityChannel(int) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
PriorityChannel(int, Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(PriorityCapableChannelMessageStore, Object) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel based on the provided PriorityCapableChannelMessageStore and group id for message store operations.
PriorityChannel(MessageGroupQueue) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel based on the provided MessageGroupQueue.
PriorityChannelSpec - Class in org.springframework.integration.dsl
 
PriorityChannelSpec() - Constructor for class org.springframework.integration.dsl.PriorityChannelSpec
 
priorityExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.PRIORITY header where the value is a SpEL Expression evaluation result.
priorityExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.PRIORITY header where the value is a SpEL Expression evaluation result.
priorityFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.PRIORITY header where the value is obtained by invoking the Function callback.
priorityFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.PRIORITY header where the value is obtained by invoking the Function callback.
ProcedureParameter - Class in org.springframework.integration.jdbc.storedproc
Abstraction of Procedure parameters allowing to provide static parameters and SpEl Expression based parameters.
ProcedureParameter(String, Object, String) - Constructor for class org.springframework.integration.jdbc.storedproc.ProcedureParameter
Instantiates a new Procedure Parameter.
ProcedureParameter() - Constructor for class org.springframework.integration.jdbc.storedproc.ProcedureParameter
Default constructor.
process(Collection<? extends Message<?>>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Processes the Message by evaluating the expression with that Message as the root object.
process(Collection<? extends Message<?>>) - Method in interface org.springframework.integration.aggregator.MessageListProcessor
 
process(Collection<Message<?>>, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
process(Message<?>) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
process(Collection<Message<?>>, Map<String, Object>) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
processAfterCommit(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processAfterCommit(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processAfterRollback(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processAfterRollback(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processAnnotationTypeOnMethod(Object, String, Method, Class<? extends Annotation>, List<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
processBeforeCommit(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processBeforeCommit(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processHeaders(Element, ManagedMap<String, Object>, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
processHeaders(Element, ManagedMap<String, Object>, ParserContext) - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.BeanNameMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
Evaluates the Message payload expression as a command.
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Processes the Message by evaluating the expression with that Message as the root object.
processMessage(Message<?>) - Method in class org.springframework.integration.handler.LambdaMessageProcessor
 
processMessage(Message<?>) - Method in interface org.springframework.integration.handler.MessageProcessor
Process the Message and return a value (or null).
processMessage(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Executes the script and returns the result.
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in interface org.springframework.integration.aggregator.MessageGroupProcessor
Process the given MessageGroup.
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.SimpleMessageGroupProcessor
 
processNioSelections(int, Selector, ServerSocketChannel, Map<SocketChannel, TcpNioConnection>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Times out any expired connections then, if selectionCount > 0, processes the selected keys.
processor(Object) - Method in class org.springframework.integration.dsl.AggregatorSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
processor(Object, String) - Method in class org.springframework.integration.dsl.AggregatorSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
processor(Object) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
processor(Resource) - Static method in class org.springframework.integration.scripting.dsl.Scripts
The factory method to produce ScriptSpec based on the Resource.
processor(String) - Static method in class org.springframework.integration.scripting.dsl.Scripts
The factory method to produce ScriptSpec based on the script file location.
processSendResult(Message<?>, ProducerRecord<K, V>, ListenableFuture<SendResult<K, V>>, MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
PROCID - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
produceOutput(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
produceOutput(Object, Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
producerListener(ProducerListener<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
Set a ProducerListener which will be invoked when Kafka acknowledges a send operation.
produces(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
The producible media types of the mapped request, narrowing the primary mapping.
producesReply(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
 
propagation(Propagation) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
PropertiesBuilder - Class in org.springframework.integration.support
A Builder pattern implementation for the Properties.
PropertiesBuilder() - Constructor for class org.springframework.integration.support.PropertiesBuilder
 
propertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
 
PropertiesPersistingMetadataStore - Class in org.springframework.integration.metadata
Properties file-based implementation of MetadataStore.
PropertiesPersistingMetadataStore() - Constructor for class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
property(String, V) - Method in class org.springframework.integration.dsl.EnricherSpec
 
propertyExpression(String, String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
propertyExpressions - Variable in class org.springframework.integration.dsl.EnricherSpec
 
propertyFunction(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.EnricherSpec
 
protocol() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Return the protocol this synchronizer works with.
protocol() - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
protocol(String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
Set the protocol.
PROTOCOL - Static variable in class org.springframework.integration.mail.Pop3MailReceiver
 
protocol() - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
proxyDefaultMethods(boolean) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Indicate if default methods on the interface should be proxied as well.
PseudoTransactionManager - Class in org.springframework.integration.transaction
An implementation of PlatformTransactionManager that provides transaction-like semantics to MessageSources that are not inherently transactional.
PseudoTransactionManager() - Constructor for class org.springframework.integration.transaction.PseudoTransactionManager
 
publish(MessagingException) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Throwable) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Message<?>, MessagingException) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Message<?>, Throwable) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Throwable, AttributeAccessor) - Method in class org.springframework.integration.core.ErrorMessagePublisher
Publish an error message for the supplied throwable and context.
publish(String) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
publish(String, Object, Message<?>) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
publish(String, Object, Message<?>) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
publishConnectionCloseEvent() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
publishConnectionExceptionEvent(Throwable) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
publishConnectionOpenEvent() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
Publisher - Annotation Type in org.springframework.integration.annotation
Annotation to indicate that a method, or all public methods if applied at class-level, should publish Messages.
PUBLISHER_ANNOTATION_POSTPROCESSOR_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
PublisherAnnotationAdvisor - Class in org.springframework.integration.aop
An advisor that will apply the MessagePublishingInterceptor to any methods containing the provided annotations.
PublisherAnnotationAdvisor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationAdvisor(Class<? extends Annotation>...) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationBeanPostProcessor - Class in org.springframework.integration.aop
Post-processes beans that contain the method-level @Publisher annotation.
PublisherAnnotationBeanPostProcessor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
PublisherDelegate() - Constructor for class org.springframework.integration.jmx.NotificationPublishingMessageHandler.PublisherDelegate
 
publisherElementType(Class<?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a type for a request Publisher elements.
publisherElementType(Function<Message<P>, ?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a Function to evaluate a request Publisher elements type at runtime against a request message.
publisherElementType(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate a request Publisher elements type at runtime against a request message.
publisherElementType(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Configure a SpEL expression to evaluate a request Publisher elements type at runtime against a request message.
publisherElementType(Class<?>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
Configure a type for a request Publisher elements.
publisherElementType(ParameterizedTypeReference<?>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
Configure a ParameterizedTypeReference for a request Publisher elements.
publisherElementTypeExpression(Expression) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
Configure a SpEL expression to evaluate a request Publisher elements type at runtime against a request message.
publisherElementTypeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
Configure a Function to evaluate a request Publisher elements type at runtime against a request message.
PublisherRegistrar - Class in org.springframework.integration.config
 
PublisherRegistrar() - Constructor for class org.springframework.integration.config.PublisherRegistrar
 
publishEvent(TcpConnectionEvent) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Allow interceptors etc to publish events, perhaps subclasses of TcpConnectionEvent.
publishEvent(Exception, byte[], int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
PublishingInterceptorParser - Class in org.springframework.integration.config.xml
Parser for the <publishing-interceptor> element.
PublishingInterceptorParser() - Constructor for class org.springframework.integration.config.xml.PublishingInterceptorParser
 
publishOnFailedToAcquire(Object, Context, String) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
publishOnFailedToAcquire(Object, Context, String) - Method in interface org.springframework.integration.leader.event.LeaderEventPublisher
Publish a failure to acquire event.
publishOnGranted(Object, Context, String) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
publishOnGranted(Object, Context, String) - Method in interface org.springframework.integration.leader.event.LeaderEventPublisher
Publish a granted event.
publishOnRevoked(Object, Context, String) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
publishOnRevoked(Object, Context, String) - Method in interface org.springframework.integration.leader.event.LeaderEventPublisher
Publish a revoked event.
publishServerExceptionEvent(Exception) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
publishServerListeningEvent(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
publishSubscribe() - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(Executor) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(String, Executor) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(String) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe() - Static method in class org.springframework.integration.dsl.MessageChannels
 
publishSubscribe(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
publishSubscribe(Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
publishSubscribe(String, Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
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.
PublishSubscribeChannel - Class in org.springframework.integration.channel
A channel that sends Messages to each of its subscribers.
PublishSubscribeChannel() - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will invoke the handlers in the message sender's thread.
PublishSubscribeChannel(Executor) - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will use an Executor to invoke the handlers.
publishSubscribeChannel(Consumer<PublishSubscribeSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
The PublishSubscribeChannel BaseIntegrationFlowDefinition.channel(java.lang.String) method specific implementation to allow the use of the 'subflow' subscriber capability.
publishSubscribeChannel(Executor, Consumer<PublishSubscribeSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
The PublishSubscribeChannel BaseIntegrationFlowDefinition.channel(java.lang.String) method specific implementation to allow the use of the 'subflow' subscriber capability.
publishSubscribeChannel(BroadcastCapableChannel, Consumer<BroadcastPublishSubscribeSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
The BroadcastCapableChannel BaseIntegrationFlowDefinition.channel(java.lang.String) method specific implementation to allow the use of the 'subflow' subscriber capability.
publishSubscribeChannel(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsPublishSubscribeMessageChannelSpec.
publishSubscribeChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
The factory to produce a JmsPublishSubscribeMessageChannelSpec.
publishSubscribeChannel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create a spec for a publish/subscribe channel with the provided parameters.
PublishSubscribeChannelParser - Class in org.springframework.integration.config.xml
Parser for the <publish-subscribe-channel> element.
PublishSubscribeChannelParser() - Constructor for class org.springframework.integration.config.xml.PublishSubscribeChannelParser
 
PublishSubscribeChannelSpec<S extends PublishSubscribeChannelSpec<S>> - Class in org.springframework.integration.dsl
 
PublishSubscribeChannelSpec() - Constructor for class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
PublishSubscribeChannelSpec(Executor) - Constructor for class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
PublishSubscribeKafkaChannel - Class in org.springframework.integration.kafka.channel
Publish/subscribe channel backed by a Kafka topic.
PublishSubscribeKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
Construct an instance with the provided parameters.
PublishSubscribeSpec - Class in org.springframework.integration.dsl
The PublishSubscribeChannelSpec extension to configure as a general flow callback for sub-flows as subscribers.
PublishSubscribeSpec() - Constructor for class org.springframework.integration.dsl.PublishSubscribeSpec
 
PublishSubscribeSpec(Executor) - Constructor for class org.springframework.integration.dsl.PublishSubscribeSpec
 
pubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
A pubSubDomain flag.
pubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
pubSubZeroMqChannel(ZContext) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqChannelSpec in pub/sub mode based on the provided ZContext.
purge() - Method in class org.springframework.integration.channel.ChannelPurger
 
purge(MessageSelector) - Method in class org.springframework.integration.channel.QueueChannel
 
purge(MessageSelector) - Method in interface org.springframework.integration.channel.QueueChannelOperations
Remove any Messages that are not accepted by the provided selector.
purgeDots(List<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
purgeLinks(List<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
purgeOrphanedGroups() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
purgeUnwantedElements(F[], Predicate<F>, Comparator<F>) - Static method in class org.springframework.integration.file.support.FileUtils
Remove entries from the array if the predicate returns true for an element.
pushSequenceDetails(Object, int, int) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
pushSequenceDetails(Object, int, int) - Method in class org.springframework.integration.support.MessageBuilder
 
put(String, Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
put(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Put the file based on the message to the remote server.
put(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
put(String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
put(String, String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
put(String, String) - Method in interface org.springframework.integration.metadata.MetadataStore
Writes a key value pair to this MetadataStore.
put(String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
put(String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
put(String, String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Store a metadata value under provided key to the configured MongoDbMetadataStore.collectionName.
put(String, String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
Persists the provided key and value to Redis.
put(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
put(K, V) - Method in class org.springframework.integration.support.MapBuilder
 
put(String, Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
put(Object, Object) - Method in class org.springframework.integration.support.PropertiesBuilder
 
put(String, String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
putAll(Map<? extends String, ?>) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
putIfAbsent(String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
putIfAbsent(String, String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
putIfAbsent(String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
Atomically insert the key into the store.
putIfAbsent(String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
putIfAbsent(String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
putIfAbsent(String, String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(String, String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
 
putIfAbsent(String, String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
PythonScriptExecutor - Class in org.springframework.integration.scripting.jsr223
A ScriptExecutor that implements special handling required for Python to emulate behavior similar to other JSR223 scripting languages.
PythonScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.PythonScriptExecutor
 
PythonScriptExecutor.PythonVariableParser - Class in org.springframework.integration.scripting.jsr223
 
PythonVariableParser() - Constructor for class org.springframework.integration.scripting.jsr223.PythonScriptExecutor.PythonVariableParser
 

Q

QOS - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
query(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
A String representation of a MongoDb Query (e.g., query("{'name' : 'Bob'}")).
queryExpression(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
A SpEL expression which should resolve to a String query (please refer to the 'query' property), or to an instance of MongoDb Query (e.q., queryExpression("new BasicQuery('{''address.state'' : ''PA''}')")).
queryFunction(Function<Message<P>, Query>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
A Function which should resolve to a Query instance.
queryType(R2dbcMessageHandler.Type) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a R2dbcMessageHandler.Type for query to execute.
queryTypeExpression(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a R2dbcMessageHandler.Type for query to execute.
queryTypeExpression(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a R2dbcMessageHandler.Type for query to execute.
queryTypeFunction(Function<Message<P>, R2dbcMessageHandler.Type>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a Function to evaluate a R2dbcMessageHandler.Type for query to execute against a request message.
queue() - Method in class org.springframework.integration.dsl.Channels
 
queue(String) - Method in class org.springframework.integration.dsl.Channels
 
queue(Integer) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, Integer) - Method in class org.springframework.integration.dsl.Channels
 
queue(Queue<Message<?>>) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, Queue<Message<?>>) - Method in class org.springframework.integration.dsl.Channels
 
queue(ChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, ChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
queue() - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(Queue<Message<?>>) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(String, Queue<Message<?>>) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(Integer) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(String, Integer) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(ChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue(String, ChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.MessageChannels
 
queue - Variable in class org.springframework.integration.dsl.QueueChannelSpec
 
QueueChannel - Class in org.springframework.integration.channel
Simple implementation of a message channel.
QueueChannel(Queue<Message<?>>) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue.
QueueChannel(int) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue capacity.
QueueChannel() - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with "unbounded" queue capacity.
QueueChannelOperations - Interface in org.springframework.integration.channel
Operations available on a channel that has queuing semantics.
QueueChannelSpec - Class in org.springframework.integration.dsl
 
QueueChannelSpec() - Constructor for class org.springframework.integration.dsl.QueueChannelSpec
 
QueueChannelSpec(Queue<Message<?>>) - Constructor for class org.springframework.integration.dsl.QueueChannelSpec
 
QueueChannelSpec(Integer) - Constructor for class org.springframework.integration.dsl.QueueChannelSpec
 
QueueChannelSpec.MessageStoreSpec - Class in org.springframework.integration.dsl
The ChannelMessageStore-specific QueueChannelSpec extension.
queueName(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
Also implicitly sets the AmqpPollableMessageChannelSpec.id(String) (if not explicitly set).
queueSemaphore - Variable in class org.springframework.integration.channel.QueueChannel
 

R

R2dbc - Class in org.springframework.integration.r2dbc.dsl
Java DSL Factory class for R2DBC components.
R2dbcMessageHandler - Class in org.springframework.integration.r2dbc.outbound
Implementation of ReactiveMessageHandler which writes Message payload into a Relational Database, using reactive r2dbc support.
R2dbcMessageHandler(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Construct this instance using a fully created and initialized instance of provided R2dbcEntityOperations
R2dbcMessageHandler.Type - Enum in org.springframework.integration.r2dbc.outbound
/** The mode for the R2dbcMessageHandler.
R2dbcMessageHandlerSpec - Class in org.springframework.integration.r2dbc.dsl
R2dbcMessageHandlerSpec(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
 
R2dbcMessageSource - Class in org.springframework.integration.r2dbc.inbound
An instance of MessageSource which returns a Message with a payload which is the result of execution of query.
R2dbcMessageSource(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Create an instance with the provided R2dbcEntityOperations and SpEL expression which should resolve to a Relational 'query' string.
R2dbcMessageSource(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Create an instance with the provided R2dbcEntityOperations and SpEL expression which should resolve to a query string or StatementMapper.SelectSpec instance.
R2dbcMessageSource.SelectCreator - Class in org.springframework.integration.r2dbc.inbound
An instance of this class is used as a root object for query expression to give a limited access only to the StatementMapper.createSelect(java.lang.String) fluent API.
R2dbcMessageSourceSpec - Class in org.springframework.integration.r2dbc.dsl
R2dbcMessageSourceSpec(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
 
R2dbcMessageSourceSpec(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
 
RateLimiterRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
An AbstractRequestHandlerAdvice extension for a rate limiting to service method calls.
RateLimiterRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Construct an instance based on default rate limiter options and "RateLimiterRequestHandlerAdvice" as a rate limiter name.
RateLimiterRequestHandlerAdvice(String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Construct an instance based on default rate limiter options and provided name.
RateLimiterRequestHandlerAdvice(RateLimiter) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Construct an instance based on the provided RateLimiter.
RateLimiterRequestHandlerAdvice(RateLimiterConfig) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Construct an instance based on the provided RateLimiterConfig and "RateLimiterRequestHandlerAdvice" as a rate limiter name.
RateLimiterRequestHandlerAdvice(RateLimiterConfig, String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Construct an instance based on the provided RateLimiterConfig and name.
RateLimiterRequestHandlerAdvice.RateLimitExceededException - Exception in org.springframework.integration.handler.advice
A MessagingException wrapper for the RequestNotPermitted with the requestMessage and target context.
raw() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
raw(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
RAW_HEADERS - Static variable in class org.springframework.integration.mail.MailHeaders
 
rawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
 
rawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
Set to true to include the raw ConsumerRecord as headers with keys KafkaHeaders.RAW_DATA and IntegrationMessageHeaderAccessor.SOURCE_DATA.
RawRecordHeaderErrorMessageStrategy - Class in org.springframework.integration.kafka.support
ErrorMessageStrategy extension that adds the raw record as a header to the ErrorMessage.
RawRecordHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 
reactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
 
reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageSourceSpec builder instance based on the provided ReactiveMongoDatabaseFactory.
reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageSourceSpec builder instance based on the provided ReactiveMongoDatabaseFactory.
reactiveInboundChannelAdapter(ReactiveMongoOperations, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageSourceSpec builder instance based on the provided ReactiveMongoOperations.
reactiveInboundChannelAdapter(ReactiveMongoOperations, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageSourceSpec builder instance based on the provided ReactiveMongoOperations.
reactiveMessageHandler - Variable in class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
 
ReactiveMessageHandlerAdapter - Class in org.springframework.integration.handler
A MessageHandler implementation to adapt a ReactiveMessageHandler for synchronous invocations.
ReactiveMessageHandlerAdapter(ReactiveMessageHandler) - Constructor for class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
Instantiate based on the provided ReactiveMessageHandler.
ReactiveMessageHandlerSpec<S extends ReactiveMessageHandlerSpec<S,H>,H extends ReactiveMessageHandler> - Class in org.springframework.integration.dsl
ReactiveMessageHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
 
ReactiveMessageSourceProducer - Class in org.springframework.integration.endpoint
ReactiveMessageSourceProducer(MessageSource<?>) - Constructor for class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
Create an instance based on the provided MessageSource.
ReactiveMongoDbMessageHandlerSpec - Class in org.springframework.integration.mongodb.dsl
A ReactiveMessageHandlerSpec extension for the Reactive MongoDb Outbound endpoint ReactiveMongoDbStoringMessageHandler.
ReactiveMongoDbMessageHandlerSpec(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
 
ReactiveMongoDbMessageHandlerSpec(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
 
ReactiveMongoDbMessageSource - Class in org.springframework.integration.mongodb.inbound
An instance of MessageSource which returns a Message with a payload which is the result of execution of a Query.
ReactiveMongoDbMessageSource(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Create an instance with the provided ReactiveMongoDatabaseFactory and SpEL expression which should resolve to a MongoDb 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
ReactiveMongoDbMessageSource(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Create an instance with the provided ReactiveMongoOperations and SpEL expression which should resolve to a Mongo 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
ReactiveMongoDbMessageSourceSpec - Class in org.springframework.integration.mongodb.dsl
ReactiveMongoDbMessageSourceSpec(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
 
ReactiveMongoDbMessageSourceSpec(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
 
ReactiveMongoDbStoringMessageHandler - Class in org.springframework.integration.mongodb.outbound
Implementation of ReactiveMessageHandler which writes Message payload into a MongoDb collection, using reactive MongoDb support, The collection is identified by evaluation of the ReactiveMongoDbStoringMessageHandler.collectionNameExpression.
ReactiveMongoDbStoringMessageHandler(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
Construct this instance using a provided ReactiveMongoDatabaseFactory
ReactiveMongoDbStoringMessageHandler(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
Construct this instance using a fully created and initialized instance of provided ReactiveMongoOperations
reactiveOutboundChannelAdapter(ReactiveMongoDatabaseFactory) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageHandlerSpec builder instance based on the provided ReactiveMongoDatabaseFactory.
reactiveOutboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
Create a ReactiveMongoDbMessageHandlerSpec builder instance based on the provided ReactiveMongoOperations.
ReactiveRedisStreamMessageHandler - Class in org.springframework.integration.redis.outbound
Implementation of ReactiveMessageHandler which writes Message payload or Message itself (see ReactiveRedisStreamMessageHandler.extractPayload) into a Redis stream using Reactive Stream operations.
ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
Create an instance based on provided ReactiveRedisConnectionFactory and key for stream.
ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
Create an instance based on provided ReactiveRedisConnectionFactory and expression for stream key.
ReactiveRedisStreamMessageProducer - Class in org.springframework.integration.redis.inbound
A MessageProducerSupport for reading messages from a Redis Stream and publishing them into the provided output channel.
ReactiveRedisStreamMessageProducer(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
 
ReactiveRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
A MethodInterceptor for message handlers producing a Mono as a payload for reply.
ReactiveRequestHandlerAdvice(BiFunction<Message<?>, Mono<?>, Publisher<?>>) - Constructor for class org.springframework.integration.handler.advice.ReactiveRequestHandlerAdvice
Instantiate advice based on a provided BiFunction customizer.
ReactiveStreamsConsumer - Class in org.springframework.integration.endpoint
An AbstractEndpoint implementation for Reactive Streams subscription into an input channel and reactive consumption of messages from that channel.
ReactiveStreamsConsumer(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
ReactiveStreamsConsumer(MessageChannel, Subscriber<Message<?>>) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
ReactiveStreamsConsumer(MessageChannel, ReactiveMessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
Instantiate an endpoint based on the provided MessageChannel and ReactiveMessageHandler.
ReactiveStreamsSubscribableChannel - Interface in org.springframework.integration.channel
 
ReactorNettyTcpStompSessionManager - Class in org.springframework.integration.stomp
ReactorNettyTcpStompSessionManager(ReactorNettyTcpStompClient) - Constructor for class org.springframework.integration.stomp.ReactorNettyTcpStompSessionManager
 
read(Kryo, Input, Class<File>) - Method in class org.springframework.integration.codec.kryo.FileSerializer
 
read(String, OutputStream) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
read(String, OutputStream) - Method in interface org.springframework.integration.file.remote.session.Session
 
read(String, OutputStream) - Method in class org.springframework.integration.ftp.session.FtpSession
 
read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
 
read(Class<? extends MultiValueMap<String, ?>>, HttpInputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
read(InputStream, byte[], boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Read data from the socket and puts the data in buffer.
read(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
read(String, OutputStream) - Method in class org.springframework.integration.sftp.session.SftpSession
 
READ_DELAY - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
READ_ONLY_HEADERS - Static variable in class org.springframework.integration.context.IntegrationProperties
readDelay(long) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
Reader(String) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
reader - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
readFraction() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
readHeader(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Read the header and returns the length of the data part.
readHeaders(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
readHeaders(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
readInt() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
Read characters building an int until a non-digit is found
readInternal(Class, HttpInputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.DefaultMultipartFileReader
 
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
 
readMultipartFile(MultipartFile) - Method in interface org.springframework.integration.http.multipart.MultipartFileReader
Reads MultipartFile content.
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
 
readOnly(boolean) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
readOnlyHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
Specify a list of headers which should be considered as read only and prohibited from being populated in the message.
readPacket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Invoked by the factory when there is data to be read.
readPayload(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
readPayload(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
readRaw(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
readRaw(String) - Method in interface org.springframework.integration.file.remote.session.Session
Retrieve a remote file as a raw InputStream.
readRaw(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
readRaw(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
rebuild() - Method in class org.springframework.integration.graph.IntegrationGraphServer
Rebuild the graph, re-cache it, and return it.
RECEIPT - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
RECEIPT_ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
ReceiptEvent - Class in org.springframework.integration.websocket.event
The AbstractSubProtocolEvent implementation, which is emitted for the WebSocket sub-protocol-specific RECEIPT frame on the client side.
ReceiptEvent(Object, Message<byte[]>) - Constructor for class org.springframework.integration.websocket.event.ReceiptEvent
 
receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
receive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
receive(long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive() - Method in class org.springframework.integration.channel.NullChannel
 
receive(long) - Method in class org.springframework.integration.channel.NullChannel
 
receive() - Method in interface org.springframework.integration.core.MessageSource
Retrieve the next available message from this source.
receive(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
 
receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receive(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
receive(long) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
receive() - Method in interface org.springframework.integration.mail.MailReceiver
 
RECEIVE_COUNTER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
 
receiveAndConvert(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
 
receiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.MessageSourceNode
 
receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.PollableChannelNode
 
ReceiveCounters - Class in org.springframework.integration.graph
Counters for components that maintain receive counters.
ReceiveCounters(long, long) - Constructor for class org.springframework.integration.graph.ReceiveCounters
 
receiveCounters(Supplier<ReceiveCounters>) - Method in interface org.springframework.integration.graph.ReceiveCountersAware
 
ReceiveCountersAware - Interface in org.springframework.integration.graph
 
RECEIVED_DATE - Static variable in class org.springframework.integration.mail.MailHeaders
 
RECEIVED_QOS - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
RECEIVED_RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
RECEIVED_TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
receivedQos(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
Return the received QOS header.
receivedRetained(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
Return the received retained header.
receivedTopic(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
Return the received topic header.
receiveMessage() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Obtain the next message (if one is available).
receiveMessage() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
receiveMessage() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
receiveMessage() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receiveMessage(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
ReceiveMessageAdvice - Interface in org.springframework.integration.aop
An AOP advice to perform hooks before and/or after a receive() contract is called.
receiver - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
receiver - Variable in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
receiveRaw(boolean) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Whether raw ZMsg is present as a payload of message to produce or it is fully converted to a Message including ZeroMqHeaders.TOPIC header (if any).
receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a timeout in milliseconds to wait for a message in the MessageChannel.
receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
A receive timeout.
receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
receiveTimeout(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
recipient(String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that always will be selected.
recipient(String, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(String, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(String, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipient(MessageChannel) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that always will be selected.
recipient(MessageChannel, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(MessageChannel, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(MessageChannel, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
Recipient(String) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
Recipient(String, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
recipientFlow(GenericSelector<P>, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
recipientFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked as a recipient.
recipientFlow(String, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the expression evaluates to 'true'.
recipientFlow(Expression, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the expression evaluates to 'true'.
RecipientListRouter - Class in org.springframework.integration.router
 <recipient-list-router id="simpleRouter" input-channel="routingChannelA">
     <recipient channel="channel1"/>
     <recipient channel="channel2"/>
 </recipient-list-router>
 
RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
 
RecipientListRouter.Recipient - Class in org.springframework.integration.router
 
RecipientListRouterManagement - Interface in org.springframework.integration.router
Exposes adding/removing individual recipients operations for RecipientListRouter.
RecipientListRouterParser - Class in org.springframework.integration.config.xml
Parser for the <recipient-list-router/> element.
RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
 
RecipientListRouterSpec - Class in org.springframework.integration.dsl
RecipientListRouterSpec() - Constructor for class org.springframework.integration.dsl.RecipientListRouterSpec
 
recipientMessageSelector(String, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipientMessageSelector(MessageChannel, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipientMessageSelectorFlow(MessageSelector, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
record(long, TimeUnit) - Method in interface org.springframework.integration.support.management.metrics.TimerFacade
 
record(long, TimeUnit) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
recordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a RecordFilterStrategy to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into FilteringMessageListenerAdapter.
recordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Set the message converter to use with a record-based consumer.
recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
 
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.
recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
Specify a recovery interval.
recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
recoveryInterval(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
RecursiveDirectoryScanner - Class in org.springframework.integration.file
The DefaultDirectoryScanner extension which walks through the directory tree using Files.walk(Path, int, FileVisitOption...).
RecursiveDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveDirectoryScanner
 
recursiveFindAnnotation(Class<? extends Annotation>, Annotation, List<Annotation>, Set<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
RedisChannelMessageStore - Class in org.springframework.integration.redis.store
Specialized Redis ChannelMessageStore that uses a list to back a QueueChannel.
RedisChannelMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelMessageStore
Construct a message store that uses Java Serialization for messages.
RedisChannelParser - Class in org.springframework.integration.redis.config
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration Redis namespace.
RedisChannelParser() - Constructor for class org.springframework.integration.redis.config.RedisChannelParser
 
RedisChannelPriorityMessageStore - Class in org.springframework.integration.redis.store
Specialized Redis PriorityCapableChannelMessageStore that uses lists to back a QueueChannel.
RedisChannelPriorityMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
RedisExceptionEvent - Class in org.springframework.integration.redis.event
 
RedisExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisExceptionEvent
 
RedisHeaders - Class in org.springframework.integration.redis.support
Pre-defined names and prefixes to be used for for dealing with headers required by Redis components
RedisInboundChannelAdapter - Class in org.springframework.integration.redis.inbound
 
RedisInboundChannelAdapter(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
RedisInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
 
RedisInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
 
RedisIntegrationEvent - Class in org.springframework.integration.redis.event
 
RedisIntegrationEvent(Object) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
 
RedisIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
 
RedisLockRegistry - Class in org.springframework.integration.redis.util
Implementation of ExpirableLockRegistry providing a distributed lock using Redis.
RedisLockRegistry(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
Constructs a lock registry with the default (60 second) lock expiration.
RedisLockRegistry(RedisConnectionFactory, String, long) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
Constructs a lock registry with the supplied lock expiration.
RedisMessageStore - Class in org.springframework.integration.redis.store
Redis implementation of the key/value style MessageStore and MessageGroupStore
RedisMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
Construct RedisMessageStore based on the provided RedisConnectionFactory and default empty prefix.
RedisMessageStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
Construct RedisMessageStore based on the provided RedisConnectionFactory and prefix.
RedisMetadataStore - Class in org.springframework.integration.redis.metadata
Redis implementation of ConcurrentMetadataStore.
RedisMetadataStore(RedisProperties) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Specifies the RedisProperties backend for this ConcurrentMetadataStore.
RedisMetadataStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Initializes the RedisProperties by provided RedisConnectionFactory and default hash key - RedisMetadataStore.KEY.
RedisMetadataStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Initializes the RedisProperties by provided RedisConnectionFactory and key.
RedisMetadataStore(RedisOperations<String, ?>) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Initializes the RedisProperties by provided RedisConnectionFactory and default hash key - RedisMetadataStore.KEY.
RedisMetadataStore(RedisOperations<String, ?>, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Initializes the RedisProperties by provided RedisConnectionFactory and key.
RedisNamespaceHandler - Class in org.springframework.integration.redis.config
Namespace handler for Spring Integration's 'redis' namespace.
RedisNamespaceHandler() - Constructor for class org.springframework.integration.redis.config.RedisNamespaceHandler
 
RedisOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
Parser for the <outbound-channel-adapter/> component.
RedisOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundChannelAdapterParser
 
RedisOutboundGateway - Class in org.springframework.integration.redis.outbound
The Gateway component implementation to perform Redis commands with provided arguments and to return command result.
RedisOutboundGateway(RedisTemplate<?, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
RedisOutboundGateway(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
RedisOutboundGatewayParser - Class in org.springframework.integration.redis.config
Parser for the <int-redis:outbound-gateway/> component.
RedisOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundGatewayParser
 
RedisPublishingMessageHandler - Class in org.springframework.integration.redis.outbound
 
RedisPublishingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
RedisQueueInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
Parser for the <queue-inbound-channel-adapter> element of the 'redis' namespace.
RedisQueueInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
 
RedisQueueInboundGateway - Class in org.springframework.integration.redis.inbound
 
RedisQueueInboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
RedisQueueInboundGatewayParser - Class in org.springframework.integration.redis.config
Parser for the <queue-inbound-gateway> element of the 'redis' namespace.
RedisQueueInboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
 
RedisQueueMessageDrivenEndpoint - Class in org.springframework.integration.redis.inbound
 
RedisQueueMessageDrivenEndpoint(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
RedisQueueOutboundChannelAdapter - Class in org.springframework.integration.redis.outbound
 
RedisQueueOutboundChannelAdapter(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
RedisQueueOutboundChannelAdapter(Expression, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
RedisQueueOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
Parser for the <int-redis:queue-outbound-channel-adapter> element.
RedisQueueOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundChannelAdapterParser
 
RedisQueueOutboundGateway - Class in org.springframework.integration.redis.outbound
 
RedisQueueOutboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
RedisQueueOutboundGatewayParser - Class in org.springframework.integration.redis.config
Parser for the <int-redis:queue-outbound-channel-adapter> element.
RedisQueueOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
RedisStoreInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
Parser for Redis store inbound adapters
RedisStoreInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreInboundChannelAdapterParser
 
RedisStoreMessageSource - Class in org.springframework.integration.redis.inbound
Inbound channel adapter which returns a Message representing a view into a Redis store.
RedisStoreMessageSource(RedisTemplate<String, ?>, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
Creates an instance with the provided RedisTemplate and SpEL expression which should resolve to a 'key' name of the collection to be used.
RedisStoreMessageSource(RedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
Creates an instance with the provided RedisConnectionFactory and SpEL expression which should resolve to a 'key' name of the collection to be used.
RedisStoreOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
Parser for the <redis:store-outbound-channel-adapter> element.
RedisStoreOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreOutboundChannelAdapterParser
 
RedisStoreWritingMessageHandler - Class in org.springframework.integration.redis.outbound
Implementation of MessageHandler which writes Message data into a Redis store identified by a key String.
RedisStoreWritingMessageHandler(RedisTemplate<String, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Constructs an instance using the provided RedisTemplate.
RedisStoreWritingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Constructs an instance using the provided RedisConnectionFactory.
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
REFRESH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
REFRESH_CHECK_DELAY_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
 
RefreshableResourceScriptSource - Class in org.springframework.integration.scripting
A ScriptSource implementation, which caches a script string and refreshes it from the target file (if modified) according the provided RefreshableResourceScriptSource.refreshDelay.
RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
The refreshCheckDelay in milliseconds for refreshable script resource.
refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
The refreshCheckDelay in milliseconds for refreshable script resource.
refreshGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
 
regexFileNameFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a simple pattern to match remote files (e.g.
regexFileNameFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
 
regexFileNameFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
 
regexFilter(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a regex pattern filter (e.g.
regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Configure a regex pattern filter (e.g.
regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
Specify a regular expression to match remote files.
regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
Specify a regular expression to match remote files (e.g.
regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
 
regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
Specify a regular expression to match remote files (e.g.
regexMputFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
A SimplePatternFileListFilter that runs against the local file system view when using MPUT command.
RegexPatternFileListFilter - Class in org.springframework.integration.file.filters
Implementation of AbstractRegexPatternMatchingFileListFilter for java.io.File instances.
RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
RegexTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
XPath MessageSelector that tests if a provided String value matches a given Regular Expression.
RegexTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Creates a selector which attempts to match the given regex and supports multiple namespaces.
RegexTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Creates a selector which attempts to match the given regex and supports a single namespace.
RegexTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Creates a non-namespaced selector which attempts to match the given regex.
RegexTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Creates a selector which attempts to match the given regex against the evaluation result of the provided XPathExpression.
RegexUtils - Class in org.springframework.integration.ip.util
Regular Expression Utilities.
register(S, Consumer<S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
register() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Register an IntegrationFlow and all the dependant and support components in the application context and return an associated IntegrationFlowContext.IntegrationFlowRegistration control object.
register() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
Register an IntegrationFlow and all the dependant and support components in the application context and return an associated IntegrationFlowRegistration control object.
registerBean(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
 
registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationRegistrar
Invoked by the framework when an @EnableIntegration annotation is encountered.
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessageHistoryRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.PublisherRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorRegistrar
 
registerChannel(String, MessageChannel) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
 
registerConverter(BeanDefinitionRegistry, BeanMetadataElement) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
 
registerEndpoint(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
 
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Registers a TcpListener to receive messages after the payload has been converted from the input data.
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
Delegate TCP Client Connection factories that are used to receive data need a Listener to send the messages to.
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
Delegate TCP Client Connection factories that are used to receive data need a Listener to send the messages to.
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Set the listener that will receive incoming Messages.
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
Register a callback for when a message group is expired through MessageGroupStore.expireMessageGroups(long).
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.NullChannel
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.QueueChannel
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
registerMetricsCaptor(MetricsCaptor) - Method in interface org.springframework.integration.support.management.IntegrationManagement
Inject a MetricsCaptor
registerOutputChannelIfCan(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
registerReplyMessageCorrelatorIfNecessary() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
registerScriptExecutorProviderIfNecessary(BeanDefinitionRegistry) - Method in class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
 
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Registers a TcpSender; for server sockets, used to provide connection information so a sender can be used to reply to incoming messages.
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
 
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Registers a sender.
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
registerSenders(List<TcpSender>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Registers the senders.
registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
registerTestListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Set a temporary listener to receive just the first incoming message.
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
registerTypes(Kryo) - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
This method is invoked by the PojoCodec and applied to the Kryo instance whenever a new instance is created.
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
registerWebSocketHandlers(WebSocketHandlerRegistry) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
registration(IntegrationFlow) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Associate provided IntegrationFlow with an IntegrationFlowContext.IntegrationFlowRegistrationBuilder for additional options and farther registration in the application context.
registration(IntegrationFlow) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Associate provided IntegrationFlow with an StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder for additional options and farther registration in the application context.
RegistrationIds - Class in org.springframework.integration.codec.kryo
Default registration ids for serializers provided by the framework.
reject(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
REJECT the associated message if the callback is not null.
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.springframework.integration.util.CallerBlocksPolicy
 
RELATIVE_PATH - Static variable in class org.springframework.integration.file.FileHeaders
 
release() - Method in class org.springframework.integration.util.UpperBound
Releases one lock on the underlying semaphore.
release(int) - Method in class org.springframework.integration.util.UpperBound
Releases several locks on the underlying semaphore.
releaseConnection() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
releaseExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an ExpressionEvaluatingReleaseStrategy for the given expression.
releaseItem(T) - Method in interface org.springframework.integration.util.Pool
Releases an item back into the pool.
releaseItem(T) - Method in class org.springframework.integration.util.SimplePool
Returns an item to the pool.
releasePartialSequences(boolean) - Method in class org.springframework.integration.dsl.ResequencerSpec
 
ReleaseStrategy - Interface in org.springframework.integration.aggregator
Strategy for determining when a group of messages reaches a state of completion (i.e.
ReleaseStrategy - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of asserting if a list of messages or payload objects is complete.
releaseStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an MethodInvokingReleaseStrategy for the target object and method name.
releaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a ReleaseStrategy.
ReleaseStrategyFactoryBean() - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
ExpressionSource implementation that accesses resource bundles using specified basenames.
ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
REMAINING_RECORDS - Static variable in class org.springframework.integration.kafka.inbound.KafkaMessageSource
The number of records remaining from the previous poll.
remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
 
REMOTE_DIRECTORY - Static variable in class org.springframework.integration.file.FileHeaders
 
REMOTE_FILE - Static variable in class org.springframework.integration.file.FileHeaders
 
REMOTE_FILE_INFO - Static variable in class org.springframework.integration.file.FileHeaders
A remote file information representation
REMOTE_HOST_PORT - Static variable in class org.springframework.integration.file.FileHeaders
A remote host/port the file has been polled from
REMOTE_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
The remote port from which a TCP message was received.
REMOTE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REMOTE_TIMEOUT_EXPRESSION - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
remoteComparator(Comparator<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Set a comparator to sort the retrieved list of F (the Type that represents the remote file) prior to applying filters and max fetch size.
remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote directory path.
remoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote directory path Function.
remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Specify the full path to the remote directory.
remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Specify the full path to the remote directory.
remoteDirectory(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Specify an expression that evaluates to the full path to the remote directory.
remoteDirectory(Function<Message<?>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Specify a function that is invoked to determine the full path to the remote directory.
remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote directory path SpEL expression.
remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Specify an expression that evaluates to the full path to the remote directory.
remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the remote directory expression used to determine the remote directory to which files will be sent.
remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the remote directory expression used to determine the remote directory to which files will be sent.
remoteDirectoryFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a Function for remote directory.
RemoteFileInboundChannelAdapterSpec<F,S extends RemoteFileInboundChannelAdapterSpec<F,S,MS>,MS extends AbstractInboundFileSynchronizingMessageSource<F>> - Class in org.springframework.integration.file.dsl
RemoteFileInboundChannelAdapterSpec(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
 
remoteFileMetadataStore(MetadataStore) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a MetadataStore for remote files metadata.
RemoteFileOperations<F> - Interface in org.springframework.integration.file.remote
Strategy for performing operations on remote files.
RemoteFileOperations.OperationsCallback<F,T> - Interface in org.springframework.integration.file.remote
Callback for using the same session for multiple RemoteFileTemplate operations.
RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
 
RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
RemoteFileOutboundGatewaySpec<F,S extends RemoteFileOutboundGatewaySpec<F,S>> - Class in org.springframework.integration.file.dsl
RemoteFileOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
 
remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote file separator symbol.
remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure the file name path separator used by the remote system.
remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the file separator when dealing with remote files; default '/'.
remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
Configure the file name path separator used by the remote system.
RemoteFileStreamingInboundChannelAdapterSpec<F,S extends RemoteFileStreamingInboundChannelAdapterSpec<F,S,MS>,MS extends AbstractRemoteFileStreamingMessageSource<F>> - Class in org.springframework.integration.file.dsl
RemoteFileStreamingInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
 
remoteFileTemplate - Variable in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
RemoteFileTemplate<F> - Class in org.springframework.integration.file.remote
A general abstraction for dealing with remote files.
RemoteFileTemplate(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.RemoteFileTemplate
Construct a RemoteFileTemplate with the supplied session factory.
remoteFileTemplateExplicitlySet(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
RemoteFileUtils - Class in org.springframework.integration.file.remote
Utility methods for supporting remote file operations.
remotePath(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
remoteTimeout(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
 
remoteTimeout(Function<Message<P>, ?>) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Configure a Function that will be invoked at runtime to determine the destination to which a message will be sent.
remove(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
remove(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
remove(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
remove(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Destroy an IntegrationFlow bean (as well as all its dependant beans) for provided flowId and clean up all the local cache for it.
remove(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Destroy an IntegrationFlow bean (as well as all its dependant beans) for provided flowId and clean up all the local cache for it.
remove(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
remove(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
remove(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
 
remove(F) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
remove(F) - Method in interface org.springframework.integration.file.filters.ResettableFileListFilter
Remove the specified file from the filter so it will pass on the next attempt.
remove(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Remove a remote file.
remove(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
remove(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
remove(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
remove(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
remove(String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
remove(int) - Method in class org.springframework.integration.history.MessageHistory
 
remove(Object) - Method in class org.springframework.integration.history.MessageHistory
 
remove(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
remove(String) - Method in interface org.springframework.integration.metadata.MetadataStore
Remove a value for the given key from this MetadataStore.
remove(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
remove(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
remove(String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Remove the metadata entry for the provided key and return its value, if any, using findAndRemove MongoDB operation.
remove(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
 
remove(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
remove(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
Remove the message from this group.
remove(UUID) - Method in class org.springframework.integration.store.MessageGroupMetadata
 
remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
remove() - Method in interface org.springframework.integration.support.management.metrics.MeterFacade
Remove this meter facade.
remove() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
 
remove(Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
remove(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
removeAll(Collection<UUID>) - Method in class org.springframework.integration.store.MessageGroupMetadata
 
removeAllIdleItems() - Method in interface org.springframework.integration.util.Pool
Removes all idle items from the pool.
removeAllIdleItems() - Method in class org.springframework.integration.util.SimplePool
 
removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Remove a channel mapping for the given key if present.
removeChannelMapping(String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
removeChannelMapping(String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Remove a channel mapping for the given key if present.
removed(ServerSession, Path, boolean, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
removeDeadConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
When we are using sockets owned by a TcpListener, this method is called each time a connection is closed.
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
removeDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
Remove a destination (or destinations) from the subscribed list and unsubscribe it.
removedFromPool(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when an item is forcibly removed from the pool - for example when the pool size is reduced.
removeFromIdCache(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Remove a Message Id from the idCache.
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Remove the handler from the internal handler Set.
removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
Remove a message handler.
removeHeader(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Remove the value for the given header name.
removeHeader(String) - Method in class org.springframework.integration.support.MessageBuilder
Remove the value for the given header name.
removeHeader(String) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
removeHeaders(String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Removes all headers provided via array of 'headerPatterns'.
removeHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
Removes all headers provided via array of 'headerPatterns'.
removeHeaders(String...) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
removeLifecycle(SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Remove the provided SmartLifecycle from all the roles, for example when a SmartLifecycle bean is destroyed.
removeListener(MetadataStoreListener) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
removeListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
Unregisters a listener
removeListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
removeMessage(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
removeMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
Remove the Message with the given id from the MessageStore, if present, and return it.
removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Remove the MessageGroup with the provided group ID.
removeMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Remove the message group with this id.
removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
removeMessagesFromGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist the deletion of messages from the group.
removeMessagesFromGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist the deletion of messages from the group.
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMeter(MeterFacade) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Remove a meter facade.
removeMeter(MeterFacade) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
removeRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
 
removeRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
 
removeRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Remove all recipients that match the channelName.
removeRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Remove all recipients that match the channelName and expression.
removeRemoteFileMetadata(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Remove a metadata for remote file associated with the provided local file.
removeSessionFactory(Object) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
Remove a session factory.
removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
Remove a topic (or topics) from the subscribed list.
removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
rename(String, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Rename a remote file, creating directories if needed.
rename(String, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
rename(String, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
rename(String, String) - Method in interface org.springframework.integration.file.remote.session.Session
 
rename(String, String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
rename(String, String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
RENAME_TO - Static variable in class org.springframework.integration.file.FileHeaders
 
renameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression for files renaming during transfer.
renameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a SpEL expression for files renaming during transfer.
renameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Specify a Function for files renaming during transfer.
rendezvous() - Method in class org.springframework.integration.dsl.Channels
 
rendezvous(String) - Method in class org.springframework.integration.dsl.Channels
 
rendezvous() - Static method in class org.springframework.integration.dsl.MessageChannels
 
rendezvous(String) - Static method in class org.springframework.integration.dsl.MessageChannels
 
RendezvousChannel - Class in org.springframework.integration.channel
A zero-capacity version of QueueChannel that delegates to a SynchronousQueue internally.
RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
 
RendezvousChannelSpec - Class in org.springframework.integration.dsl
 
RendezvousChannelSpec() - Constructor for class org.springframework.integration.dsl.RendezvousChannelSpec
 
renew(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
renew(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
 
RenewableLockRegistry - Interface in org.springframework.integration.support.locks
A LockRegistry implementing this interface supports the renewal of the time to live of a lock.
renewLock(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
renewLock(Object) - Method in interface org.springframework.integration.support.locks.RenewableLockRegistry
Renew the time to live of the lock is associated with the parameter object.
reopen(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
If true, close and reopen the file between reading chunks.
replace(String, String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
replace(String, String, String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
replace(String, String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
Atomically replace the value for the key in the store if the old value matches the oldValue argument.
replace(String, String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
replace(String, String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
replace(String, String, String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Replace an existing metadata entry value with a new one.
replace(String, String, String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
 
replace(String, String, String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Convenience method allowing conversion of a list of mappings in a control-bus message.
replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
replaceChannelMappings(Properties) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide mappings from channel keys to channel names.
replaceRecipients(Properties) - Method in class org.springframework.integration.router.RecipientListRouter
 
replaceRecipients(Properties) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Replace recipient.
REPLY_CHANNEL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
 
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
replyChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set a reply channel.
replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set a reply channel.
replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies the default channel the gateway proxy will subscribe to, to receive reply Messages, the payloads of which will be converted to the return type of the method signature.
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies the default channel the gateway proxy will subscribe to, to receive reply Messages, the payloads of which will be converted to the return type of the method signature.
replyChannel(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header: bean name or instance.
replyChannel(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header: bean name or instance.
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A reply channel to use.
replyChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A reply channel name to use.
replyChannelExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header where the value is a SpEL Expression evaluation result.
replyChannelExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header where the value is a SpEL Expression evaluation result.
replyChannelFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header where the value is obtained by invoking the Function callback.
replyChannelFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.REPLY_CHANNEL header where the value is obtained by invoking the Function callback.
replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
Override to allow 'reply-channel' within a chain, for components where it makes sense (e.g.
replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.EnricherParser
 
replyContainer() - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
Configure a reply container with default properties.
replyContainer(Consumer<JmsOutboundGatewaySpec.ReplyContainerSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
Configure a reply container with a reply container specification determined by invoking the Consumer callback with a JmsOutboundGatewaySpec.ReplyContainerSpec.
ReplyContainerProperties() - Constructor for class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
replyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
replyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
replyDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
replyDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
Configure a Function that will be invoked at run time to determine the destination from which a reply will be received.
replyDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
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.
replyKey(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
Specify the key to be used when adding the reply Message or payload to the core map (will be payload only unless the value of BaseHttpInboundEndpoint.setExtractReplyPayload(boolean) is false).
replyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
replyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
Set a message converter for replies (when a gateway).
replyPayloadToFlux(boolean) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
The boolean flag to identify if the reply payload should be as a Flux from the response body or as resolved value from the Mono of the response body.
replyPriority(int) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
ReplyProducingMessageHandlerWrapper - Class in org.springframework.integration.handler
The AbstractReplyProducingMessageHandler wrapper around raw MessageHandler for request-reply scenarios, e.g.
ReplyProducingMessageHandlerWrapper(MessageHandler) - Constructor for class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
replyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
ReplyRequiredException - Exception in org.springframework.integration.handler
Exception that indicates no reply message is produced by a handler that does have a value of true for the 'requiresReply' property.
ReplyRequiredException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
 
ReplyRequiredException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
 
replyTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
 
replyTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set a reply timeout.
replyTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Allows to specify how long this gateway will wait for the reply Message before returning.
replyTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A reply timeout to use.
replyTimeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
replyTo(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the ReplyTo: address.
replyToExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine the ReplyTo: address.
replyToFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the ReplyTo: address based on the message.
request - Variable in class org.springframework.integration.ftp.server.FtpRequestEvent
 
REQUEST_HANDLER_ADVICE_CHAIN - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
REQUEST_METHOD - Static variable in class org.springframework.integration.http.HttpHeaders
 
REQUEST_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REQUEST_URL - Static variable in class org.springframework.integration.http.HttpHeaders
 
requestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Specify the WebServiceMessageCallback to use.
requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A request channel to use.
requestChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A request channel name to use.
requestDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
requestDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
requestDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
Configure a Function that will be invoked at runtime to determine the destination to which a message will be sent.
requestDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
requestedContentTypeResolver(RequestedContentTypeResolver) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
 
requestElementType(ResolvableType) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
Specify a type of payload to be generated when the inbound RSocket request content is read by the converters/encoders.
requestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
Set the ClientHttpRequestFactory for the underlying RestTemplate.
RequestHandlerCircuitBreakerAdvice - Class in org.springframework.integration.handler.advice
A circuit breaker that stops calling a failing service after threshold failures, until halfOpenAfter milliseconds has elapsed.
RequestHandlerCircuitBreakerAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException - Exception in org.springframework.integration.handler.advice
An exception thrown when the circuit breaker is in an open state.
RequestHandlerRetryAdvice - Class in org.springframework.integration.handler.advice
Uses spring-retry to perform stateless or stateful retry.
RequestHandlerRetryAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
requestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
requestMapping - Variable in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
requestMapping(Consumer<HttpInboundEndpointSupportSpec.RequestMappingSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
RequestMapping - Class in org.springframework.integration.http.inbound
Class for mapping web requests onto specific HttpRequestHandlingEndpointSupport.
RequestMapping() - Constructor for class org.springframework.integration.http.inbound.RequestMapping
 
RequestMessageCallback(WebServiceMessageCallback, Message<?>) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
 
requestPayload(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestPayloadExpression(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestPayloadType(Class<?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify the type of payload to be generated when the inbound HTTP request content is read by the HttpMessageConverters.
requestPayloadType(ResolvableType) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify the type of payload to be generated when the inbound HTTP request content is read by the HttpMessageConverters.
requestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
RequestReplyExchanger - Interface in org.springframework.integration.gateway
Interface for a request/reply Message exchange.
RequestReplyHeaderMapper<T> - Interface in org.springframework.integration.mapping
Request/Reply strategy interface for mapping MessageHeaders to and from other types of objects.
RequestResponseScenario - Class in org.springframework.integration.test.support
Defines a Spring Integration request response test scenario.
RequestResponseScenario(String, String) - Constructor for class org.springframework.integration.test.support.RequestResponseScenario
Create an instance
requestSubFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EnricherSpec
The request sub-flow.
requestTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set a request timeout.
requestTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Provides the amount of time dispatcher would wait to send a Message.
requestTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
A request timeout to use.
requeue(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
REQUEUE the associated message if the callback is not null.
requiresDestruction(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition.ReplyProducerCleaner
 
requiresDestruction(Object) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
requiresDestruction(Object) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
requiresDestruction(Object) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
requiresDestruction(Object) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
requiresReply(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
 
requiresReply(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
rescheduleAt(Message<?>, Date) - Method in class org.springframework.integration.handler.DelayHandler
 
reschedulePersistedMessages() - Method in class org.springframework.integration.handler.DelayHandler
Used for reading persisted Messages in the 'messageStore' to reschedule them e.g.
reschedulePersistedMessages() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
 
resequence() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ResequencingMessageHandler with default options.
resequence(Consumer<ResequencerSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ResequencingMessageHandler with provided options from ResequencerSpec.
ResequencerParser - Class in org.springframework.integration.config.xml
Parser for the <resequencer> element.
ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
 
ResequencerSpec - Class in org.springframework.integration.dsl
 
ResequencerSpec() - Constructor for class org.springframework.integration.dsl.ResequencerSpec
 
ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
This class implements all the strategy interfaces needed for a default resequencer.
ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
ResequencingMessageHandler - Class in org.springframework.integration.aggregator
Resequencer specific implementation of AbstractCorrelatingMessageHandler.
ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
ResequencingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
reset() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
Resume polling at the next Trigger event.
reset() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
resetBeans(String...) - Method in class org.springframework.integration.test.context.MockIntegrationContext
Reinstate the mocked beans after execution test to their real state.
resetCache() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Clear the cache of sessions; also any in-use sessions will be closed when returned to the cache.
resetServer() - Method in class org.springframework.integration.test.mail.TestMailServer.ImapServer
 
resetServer() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
resetSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
Resets the shared session so the next #getSession() will return a session using a new connection.
resetSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
ResettableFileListFilter<F> - Interface in org.springframework.integration.file.filters
A FileListFilter that can be reset by removing a specific file from its state.
resolutionRequired(boolean) - Method in class org.springframework.integration.dsl.RouterSpec
 
RESOLVABLE_TYPE - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
The header to represent a ResolvableType for the target deserialized object.
resolve(String, Message<?>) - Method in interface org.springframework.integration.redis.outbound.ArgumentsStrategy
 
resolve(String, Message<?>) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.CollectionArgumentResolver
 
resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.MapArgumentResolver
 
resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
 
resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadsArgumentResolver
 
resolveAttribute(List<Annotation>, String, Class<T>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Get the attribute value from the annotation hierarchy, returning the first non-empty value closest to the annotated method.
resolveAttributeToBoolean(String) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
resolveDestination(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
resolveErrorChannel(MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
resolveHttpStatusFromHeaders(MessageHeaders) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
resolvePrimitiveType(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Resolve the given class if it is a primitive wrapper class, returning the corresponding primitive type instead.
resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
Resolves the sessionId for the given message using the SubProtocolHandler.resolveSessionId(org.springframework.messaging.Message<?>) algorithm.
resolveTargetBeanFromMethodWithBeanAnnotation(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
resolveTargetBeanFromMethodWithBeanAnnotation(Method) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
resolveTargetBeanName(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
resourceHolder - Variable in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
ResourceInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for 'resource-inbound-channel-adapter'
ResourceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
 
ResourceRetrievingMessageSource - Class in org.springframework.integration.resource
Implementation of MessageSource based on ResourcePatternResolver which will attempt to resolve Resources based on the pattern specified.
ResourceRetrievingMessageSource(String) - Constructor for class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
ResponseMessageExtractor() - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
rest() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
restartAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
If exposed as an MBean, can be used to restart the ack thread if a fatal (bind) error occurred, without bouncing the JVM.
ResultFactory - Interface in org.springframework.integration.xml.result
Factory to create a Result possibly taking into account the provided message payload instance.
ResultToDocumentTransformer - Class in org.springframework.integration.xml.transformer
Creates a Document from a Result payload.
ResultToDocumentTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
ResultToDocumentTransformer(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
ResultToStringTransformer - Class in org.springframework.integration.xml.transformer
Converts the passed Result to an instance of String.
ResultToStringTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
ResultToStringTransformer(TransformerFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
Construct an instance based on the provided TransformerFactory.
ResultTransformer - Interface in org.springframework.integration.xml.transformer
Implementations of this class allow for the transformation of Result objects to other formats.
resume() - Method in interface org.springframework.integration.core.Pausable
Resume the endpoint if paused.
resume() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
retainOriginal - Variable in class org.springframework.integration.syslog.RFC5424SyslogParser
 
retrieveMBeanNames() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
retrievingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaRetrievingOutboundGatewaySpec builder instance for request-reply gateway based on the provided EntityManagerFactory.
retrievingGateway(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaRetrievingOutboundGatewaySpec builder instance for request-reply gateway based on the provided EntityManager.
retrievingGateway(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaRetrievingOutboundGatewaySpec builder instance for request-reply gateway based on the provided JpaOperations.
RetrievingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
The Parser for the Retrieving Jpa Outbound Gateway.
RetrievingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.RetrievingJpaOutboundGatewayParser
 
RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
RetryAdviceParser - Class in org.springframework.integration.config.xml
 
RetryAdviceParser() - Constructor for class org.springframework.integration.config.xml.RetryAdviceParser
 
retryConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
Immediately attempt to establish the connection.
retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
retryDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Set an additional delay to apply when retrying after a release failure.
RetryExceptionNotAvailableException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException
 
retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
retryOps - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
RetryStateGenerator - Interface in org.springframework.integration.handler.advice
Strategy interface for generating a RetryState instance based on a message.
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.
retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Specify a RetryTemplate instance to wrap KafkaInboundGateway.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
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
 
ReversibleFileListFilter<F> - Interface in org.springframework.integration.file.filters
A FileListFilter that allows the caller to reverse (roll back) state changes.
revertLogLevels(String, TestUtils.LevelsContainer) - Static method in class org.springframework.integration.test.util.TestUtils
 
RFC5424MessageConverter - Class in org.springframework.integration.syslog
MessageConverter; delegates to a RFC5424SyslogParser if necessary (TCP will have already done the syslog conversion because it needs to handle different message framing).
RFC5424MessageConverter() - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
Construct an instance with a default RFC5424SyslogParser.
RFC5424MessageConverter(RFC5424SyslogParser) - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
Construct an instance with a non-standard parser.
RFC5424SyslogParser - Class in org.springframework.integration.syslog
Parse for RFC 5424 syslog messages; when used with TCP, requires the use of a RFC6587SyslogDeserializer which decodes the framing.
RFC5424SyslogParser() - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
Construct a default parser; do not retain the original message content unless there is an error.
RFC5424SyslogParser(boolean) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
 
RFC5424SyslogParser.Reader - Class in org.springframework.integration.syslog
 
RFC5424SyslogParser.Severity - Enum in org.springframework.integration.syslog
 
RFC6587SyslogDeserializer - Class in org.springframework.integration.syslog.inbound
RFC5424/6587 Deserializer.
RFC6587SyslogDeserializer() - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
Construct an instance using a ByteArrayLfSerializer for non-transparent frames.
RFC6587SyslogDeserializer(Deserializer<byte[]>) - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
Construct an instance using the specified Deserializer for non-transparent frames.
rm(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Perform remote delete for the provided path.
rm(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
rmdir(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
rmdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
Remove a remote directory.
rmdir(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
rmdir(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
RmiInboundGateway - Class in org.springframework.integration.rmi
Deprecated.
since 5.4 with no replacement.
RmiInboundGateway() - Constructor for class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
RmiInboundGatewayParser - Class in org.springframework.integration.rmi.config
Deprecated.
since 5.4 with no replacement.
RmiInboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiInboundGatewayParser
Deprecated.
 
RmiNamespaceHandler - Class in org.springframework.integration.rmi.config
Deprecated.
since 5.4 with no replacement.
RmiNamespaceHandler() - Constructor for class org.springframework.integration.rmi.config.RmiNamespaceHandler
Deprecated.
 
RmiOutboundGateway - Class in org.springframework.integration.rmi
Deprecated.
since 5.4 with no replacement.
RmiOutboundGateway(String) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
Deprecated.
Construct an instance with a `RequestReplyExchanger` built from the default RmiProxyFactoryBean.
RmiOutboundGateway(String, RmiOutboundGateway.RmiProxyFactoryBeanConfigurer) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
Deprecated.
Construct an instance with a `RequestReplyExchanger` built from the default RmiProxyFactoryBean which can be modified by the configurer.
RmiOutboundGateway.RmiProxyFactoryBeanConfigurer - Interface in org.springframework.integration.rmi
Deprecated.
Allows configuration of the proxy factory bean before the RMI proxy is created.
RmiOutboundGatewayParser - Class in org.springframework.integration.rmi.config
Deprecated.
since 5.4 with no replacement.
RmiOutboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
Deprecated.
 
Role - Annotation Type in org.springframework.integration.annotation
Annotate endpoints to assign them to a role.
ROLE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
role(String) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
role(String) - Method in class org.springframework.integration.dsl.EndpointSpec
Specify the role for the endpoint.
role(String) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Indicate that not all files previously passed by this filter (in FileListFilter.filterFiles(Object[]) have been processed; the file must be in the list of files; it, and all files after it, will be considered to have not been processed and will be considered next time.
rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
 
rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
rollback(F, List<F>) - Method in interface org.springframework.integration.file.filters.ReversibleFileListFilter
Indicate that not all files previously passed by this filter (in FileListFilter.filterFiles(Object[]) have been processed; the file must be in the list of files; it, and all files after it, will be considered to have not been processed and will be considered next time.
rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
ROME_TOOLS_PRESENT - Static variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
RotatingServerAdvice - Class in org.springframework.integration.file.remote.aop
A smart poller advice that rotates across multiple remote servers/directories.
RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
Create an instance that rotates to the next server/directory if no message is received.
RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>, boolean) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
Create an instance that rotates to the next server/directory depending on the fair argument.
RotatingServerAdvice(RotationPolicy) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
Construct an instance that rotates according to the supplied RotationPolicy.
RotationPolicy - Interface in org.springframework.integration.file.remote.aop
A strategy for rotating advices to allow reconfiguring the message source before and/or after a poll.
RotationPolicy.KeyDirectory - Class in org.springframework.integration.file.remote.aop
A key for a thread-local store and its related directory pair.
RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
Round-robin implementation of LoadBalancingStrategy.
RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
 
route(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for provided bean and its method with default options.
route(String, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for provided bean and its method with provided options from RouterSpec.
route(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for the discovered method of the provided service and its method with default options.
route(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for the method of the provided service and its method with default options.
route(Object, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for the method of the provided service and its method with provided options from RouterSpec.
route(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ExpressionEvaluatingRouter for provided SpEL expression with default options.
route(String, Consumer<RouterSpec<T, ExpressionEvaluatingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ExpressionEvaluatingRouter for provided SpEL expression with provided options from RouterSpec.
route(Class<S>, Function<S, T>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function and payload type with default options.
route(Class<P>, Function<P, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function and payload type and options from RouterSpec.
route(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for the MessageProcessor from the provided MessageProcessorSpec with default options.
route(MessageProcessorSpec<?>, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingRouter for the MessageProcessor from the provided MessageProcessorSpec with default options.
route(S, Consumer<S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
route(AbstractMessageRouter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageRouter implementation to the current integration flow position.
route(R, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageRouter implementation to the current integration flow position.
route(Function<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function with default options.
route(Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function with provided options from RouterSpec.
routeByException(Consumer<RouterSpec<Class<? extends Throwable>, ErrorMessageExceptionTypeRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ErrorMessageExceptionTypeRouter with options from the RouterSpec.
Router - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of resolving to a channel or channel name based on a message, message header(s), or both.
RouterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Router.
RouterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
 
RouterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Router.
RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
 
RouterSpec<K,R extends AbstractMappingMessageRouter> - Class in org.springframework.integration.dsl
RouterSpec(R) - Constructor for class org.springframework.integration.dsl.RouterSpec
 
routeToRecipients(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the RecipientListRouter with options from the RecipientListRouterSpec.
ROUTING_SLIP - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
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.
RoutingMessageHandlerNode - Class in org.springframework.integration.graph
Represents an endpoint that can route to multiple channels.
RoutingMessageHandlerNode(int, String, MessageHandler, String, String, Collection<String>) - Constructor for class org.springframework.integration.graph.RoutingMessageHandlerNode
 
routingSlip(Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
routingSlip(Boolean, Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
RoutingSlipHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
The RoutingSlip HeaderValueMessageProcessor specific implementation.
RoutingSlipHeaderValueMessageProcessor(Object...) - Constructor for class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
RoutingSlipRouteStrategy - Interface in org.springframework.integration.routingslip
The RoutingSlip strategy to determine the next replyChannel.
RSocketConnectedEvent - Class in org.springframework.integration.rsocket
An IntegrationEvent to indicate that RSocket from the client is connected to the server.
RSocketConnectedEvent(Object, Map<String, Object>, DataBuffer, RSocketRequester) - Constructor for class org.springframework.integration.rsocket.RSocketConnectedEvent
 
rsocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
Provide an AbstractRSocketConnector reference for an explicit endpoint mapping.
RSocketInboundGateway - Class in org.springframework.integration.rsocket.inbound
RSocketInboundGateway(String...) - Constructor for class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Instantiate based on the provided path patterns to map this endpoint for incoming RSocket requests.
RSocketInboundGatewayParser - Class in org.springframework.integration.rsocket.config
Parser for the <inbound-gateway/> element of the 'rsocket' namespace.
RSocketInboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
 
RSocketInboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
The MessagingGatewaySpec implementation for the RSocketInboundGateway.
RSocketInboundGatewaySpec(String...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
 
RSocketInteractionModel - Enum in org.springframework.integration.rsocket
The RSocket protocol interaction models.
rSocketMessageHandler - Variable in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
RSocketNamespaceHandler - Class in org.springframework.integration.rsocket.config
Namespace handler for Spring Integration XML configuration for RSocket support.
RSocketNamespaceHandler() - Constructor for class org.springframework.integration.rsocket.config.RSocketNamespaceHandler
 
RSocketOutboundGateway - Class in org.springframework.integration.rsocket.outbound
An Outbound Messaging Gateway for RSocket requests.
RSocketOutboundGateway(String, Object...) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Instantiate based on the provided RSocket endpoint route and optional variables to expand route template.
RSocketOutboundGateway(Expression) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Instantiate based on the provided SpEL expression to evaluate an RSocket endpoint route at runtime against a request message.
RSocketOutboundGatewayParser - Class in org.springframework.integration.rsocket.config
Parser for the 'outbound-gateway' element of the rsocket namespace.
RSocketOutboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
 
RSocketOutboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
The MessageHandlerSpec implementation for the RSocketOutboundGateway.
RSocketOutboundGatewaySpec(String, Object...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
 
RSocketOutboundGatewaySpec(Expression) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
 
RSockets - Class in org.springframework.integration.rsocket.dsl
The RSocket components Factory.
rsocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
Configure an RSocketStrategies instead of a default one.
RubyScriptExecutor - Class in org.springframework.integration.scripting.jsr223
A DefaultScriptExecutor extension for Ruby scripting support.
RubyScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.RubyScriptExecutor
 
run() - Method in class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
 
run() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
run() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
Reads lines from stdout and sends in a message to the output channel.
run() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
If there is no listener, this method exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
If no listener registers, exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
If there is no listener, this method exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
If no listener registers, exits.
run() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
run() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Process acknowledgments, if requested.
run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Expire all message groups older than the timeout provided.
run() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
run() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
runReaper() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Cancel the scheduled reap task and run immediately; then reschedule.
runReaper() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
Cancel the scheduled reap task and run immediately; then reschedule.

S

sameExceptIgnorableHeaders(Message<P>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
SampleFacade - Interface in org.springframework.integration.support.management.metrics
 
sb - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
scanEachPoll(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Set this flag if you want to make sure the internal queue is refreshed with the latest content of the input directory on each poll.
scanner(DirectoryScanner) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Specify a custom scanner.
scanner(DirectoryScanner) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a scanner to use for the file system scan after transfer.
scatterGather(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and default AggregatorSpec for gathering function.
scatterGather(MessageChannel, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and AggregatorSpec for gathering function.
scatterGather(MessageChannel, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and default AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and AggregatorSpec for gathering function.
ScatterGatherHandler - Class in org.springframework.integration.scattergather
The MessageHandler implementation for the Scatter-Gather EIP pattern.
ScatterGatherHandler(MessageHandler, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
 
ScatterGatherHandler(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
 
ScatterGatherParser - Class in org.springframework.integration.config.xml
Parser for the <scatter-gather> element.
ScatterGatherParser() - Constructor for class org.springframework.integration.config.xml.ScatterGatherParser
 
ScatterGatherSpec - Class in org.springframework.integration.dsl
ScatterGatherSpec(ScatterGatherHandler) - Constructor for class org.springframework.integration.dsl.ScatterGatherSpec
 
SCHEDULER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
ScriptExecutingMessageProcessor - Class in org.springframework.integration.scripting.jsr223
An AbstractScriptExecutingMessageProcessor implementation for evaluating scripts from the provided ScriptSource in the provided ScriptExecutor against an optional binding variables.
ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
Create a processor for the ScriptSource using the provided ScriptExecutor using the DefaultScriptVariableGenerator
ScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
Create a processor for the ScriptSource using the provided ScriptExecutor
ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor, Map<String, Object>) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
Create a processor for the ScriptSource using the provided ScriptExecutor using the DefaultScriptVariableGenerator
ScriptExecutingMessageSource - Class in org.springframework.integration.scripting
The MessageSource strategy implementation to produce a Message from underlying ScriptExecutingMessageSource.scriptMessageProcessor for polling endpoints.
ScriptExecutingMessageSource(AbstractScriptExecutingMessageProcessor<?>) - Constructor for class org.springframework.integration.scripting.ScriptExecutingMessageSource
 
ScriptExecutingProcessorFactory - Class in org.springframework.integration.scripting.config
The factory to create AbstractScriptExecutingMessageProcessor instances for provided arguments.
ScriptExecutingProcessorFactory() - Constructor for class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
 
ScriptExecutor - Interface in org.springframework.integration.scripting
A script evaluation abstraction against ScriptSource and optional binding variables.
ScriptExecutorFactory - Class in org.springframework.integration.scripting.jsr223
The scripting configuration utilities.
ScriptingException - Exception in org.springframework.integration.scripting
 
ScriptingException(String) - Constructor for exception org.springframework.integration.scripting.ScriptingException
 
ScriptingException(String, Throwable) - Constructor for exception org.springframework.integration.scripting.ScriptingException
 
ScriptMessageSourceSpec - Class in org.springframework.integration.scripting.dsl
The MessageSourceSpec for Dynamic Language Scripts.
ScriptMessageSourceSpec(Resource) - Constructor for class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
 
ScriptMessageSourceSpec(String) - Constructor for class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
 
ScriptNamespaceHandler - Class in org.springframework.integration.scripting.config.jsr223
 
ScriptNamespaceHandler() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptNamespaceHandler
 
ScriptParser - Class in org.springframework.integration.scripting.config.jsr223
An AbstractScriptParser parser extension for the <int-script:script> tag.
ScriptParser() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
Scripts - Class in org.springframework.integration.scripting.dsl
The factory for Dynamic Language Scripts (Groovy, Ruby, Python, JavaScript etc.).
ScriptSpec - Class in org.springframework.integration.scripting.dsl
The MessageProcessorSpec implementation for the DslScriptExecutingMessageProcessor.
ScriptVariableGenerator - Interface in org.springframework.integration.scripting
Strategy interface to provide a Map of variables to the script execution context.
searchForNewMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Subclasses must implement this method to return new mail messages.
searchForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
Retrieves new messages from this receiver's folder.
searchForNewMessages() - Method in class org.springframework.integration.mail.Pop3MailReceiver
 
searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
SearchTermStrategy - Interface in org.springframework.integration.mail
Strategy to be used to generate a SearchTerm See ImapMailReceiver
SecuredChannel - Annotation Type in org.springframework.integration.security.channel
An annotation to be applied for the MessageChannel bean definition from JavaConfig - on @Bean method level.
SecuredChannelsParser - Class in org.springframework.integration.security.config
Creates a ChannelSecurityInterceptor to control send and receive access, and creates a bean post-processor to apply the interceptor to MessageChannels whose names match the specified patterns.
SecuredChannelsParser() - Constructor for class org.springframework.integration.security.config.SecuredChannelsParser
 
SecurityContextPropagationChannelInterceptor - Class in org.springframework.integration.security.channel
The ExecutorChannelInterceptor implementation responsible for the SecurityContext propagation from one message flow's thread to another through the MessageChannels involved in the flow.
SecurityContextPropagationChannelInterceptor() - Constructor for class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
 
SecurityIntegrationConfigurationInitializer - Class in org.springframework.integration.security.config
The Integration Security infrastructure beanFactory initializer.
SecurityIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.security.config.SecurityIntegrationConfigurationInitializer
 
selector(String) - Method in class org.springframework.integration.dsl.WireTapSpec
 
selector(Expression) - Method in class org.springframework.integration.dsl.WireTapSpec
Specify an Expression for selector.
selector(MessageSelector) - Method in class org.springframework.integration.dsl.WireTapSpec
 
selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Configure a Function to select messages.
selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Configure a Function to select messages.
SELECTOR_ACCEPT_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The org.springframework.integration.core.GenericSelector#accept(Object) method object.
SelectorChainParser - Class in org.springframework.integration.config.xml
Parser for the <selector-chain/> element.
SelectorChainParser() - Constructor for class org.springframework.integration.config.xml.SelectorChainParser
 
selectorExpression(String) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Configure a SpEL expression to select messages.
selectorExpression(Expression) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Configure an Expression to select messages.
selectorExpression(String) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Configure a SpEL expression to select messages.
selectorExpression(Expression) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Configure a SpEL expression to select messages.
SelectorParser - Class in org.springframework.integration.config.xml
Parser for a top-level <selector/> element.
SelectorParser() - Constructor for class org.springframework.integration.config.xml.SelectorParser
 
send(Message<?>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
send(Message<?>) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
send(Message<?>, FileExistsMode...) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Send a file to a remote server, based on information in a message.
send(Message<?>, String, FileExistsMode...) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Send a file to a remote server, based on information in a message.
send(Message<?>, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
send(Message<?>, String, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
send(String) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
send(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
send(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Converts and sends the message.
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
SEND_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
SEND_TIMER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
 
sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
 
sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendAndReceiveMessageReactive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sender - Variable in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
 
sendErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
sendErrorMessageIfNecessary(Message<?>, Exception) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Send an error message based on the exception and message.
sendExceptionToListener(Exception) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which failed send results are sent.
sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which failed send results are sent.
sendingTaskExecutor(Executor) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Specify a task executor to be used to send messages to the downstream flow.
sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
sendOutput(Object, Object, boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Send an output Message.
sendOutputs(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
sendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
sendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
The Consumer callback to configure a publishing socket.
sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which successful send results are sent.
sendSuccessChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which successful send results are sent.
sendTimeout(long) - Method in class org.springframework.integration.dsl.BarrierSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the default timeout value to use for send operations.
sendTimeout(long) - Method in class org.springframework.integration.dsl.PollerSpec
 
sendTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Specify a timeout in milliseconds how long KafkaProducerMessageHandler should wait wait for send operation results.
sendTimer() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendTimer() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
sendTimers(Supplier<SendTimers>) - Method in class org.springframework.integration.graph.MessageChannelNode
 
sendTimers(Supplier<SendTimers>) - Method in class org.springframework.integration.graph.MessageHandlerNode
 
SendTimers - Class in org.springframework.integration.graph
Success and failure timer stats.
SendTimers(TimerStats, TimerStats) - Constructor for class org.springframework.integration.graph.SendTimers
 
sendTimers(Supplier<SendTimers>) - Method in interface org.springframework.integration.graph.SendTimersAware
 
SendTimersAware - Interface in org.springframework.integration.graph
 
sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
Overrides super class method to perform decryption and/or participate in handshaking.
SEQUENCE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
SEQUENCE_DETAILS - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SEQUENCE_NAME - Static variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
SEQUENCE_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
SEQUENCE_NUMBER - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SEQUENCE_SIZE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SequenceAwareMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
 
SequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
An implementation of ReleaseStrategy that simply compares the current size of the message list to the expected 'sequenceSize'.
SequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
Construct an instance that does not support releasing partial sequences.
SequenceSizeReleaseStrategy(boolean) - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
Construct an instance that supports releasing partial sequences if releasePartialSequences is true.
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
Writes the byte[] to the stream and appends \r\n.
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Write the byte[] to the output stream, preceded by a 4 byte length in network byte order (big endian).
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
 
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
Writes the byte[] to the stream and appends the terminator.
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
Writes the byte[] to the stream, prefixed by an ASCII STX character and terminated with an ASCII ETX character.
serialize(Map<?, ?>, OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
 
serialize(MessageHeaders, JsonGenerator, SerializerProvider) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
serialize(MimeType, JsonGenerator, SerializerProvider) - Method in class org.springframework.integration.support.json.MimeTypeSerializer
 
serializer() - Static method in class org.springframework.integration.dsl.Transformers
 
serializer(Serializer<Object>) - Static method in class org.springframework.integration.dsl.Transformers
 
serializer(Serializer<?>) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
serializeWithType(MessageHeaders, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
serializeWithType(MimeType, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MimeTypeSerializer
 
SerializingHttpMessageConverter - Class in org.springframework.integration.http.converter
An HttpMessageConverter implementation for Serializable instances.
SerializingHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.SerializingHttpMessageConverter
Creates a new instance of the SerializingHttpMessageConverter.
SERVER - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
ServerRSocketConnector - Class in org.springframework.integration.rsocket
A server AbstractRSocketConnector extension to accept and manage client RSocket connections.
ServerRSocketConnector(ServerRSocketMessageHandler) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
Instantiate a server connector based on a provided ServerRSocketMessageHandler with an assumption that RSocket server is created externally as well.
ServerRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
Instantiate a server connector based on the TcpServerTransport.
ServerRSocketConnector(HttpServer) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
Instantiate a server connector based on the WebsocketServerTransport.
ServerRSocketConnector(ServerTransport<CloseableChannel>) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
Instantiate a server connector based on the provided ServerTransport.
ServerRSocketMessageHandler - Class in org.springframework.integration.rsocket
An IntegrationRSocketMessageHandler extension for RSocket service side.
ServerRSocketMessageHandler() - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Create an service side RSocket message handler instance for delegating to IntegrationRSocketEndpoint beans and collect RSocketRequesters from client connections.
ServerRSocketMessageHandler(boolean) - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Create an service side RSocket message handler instance for delegating to IntegrationRSocketEndpoint beans and collect RSocketRequesters from client connections.
ServerWebSocketContainer - Class in org.springframework.integration.websocket
The IntegrationWebSocketContainer implementation for the server WebSocketHandler registration.
ServerWebSocketContainer(String...) - Constructor for class org.springframework.integration.websocket.ServerWebSocketContainer
 
ServerWebSocketContainer.SockJsServiceOptions - Class in org.springframework.integration.websocket
 
ServerWebSocketContainerParser - Class in org.springframework.integration.websocket.config
The AbstractSingleBeanDefinitionParser implementation for the <websocket:server-container/> element.
ServerWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
 
SERVICE_NAME_PREFIX - Static variable in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
ServiceActivatingHandler - Class in org.springframework.integration.handler
 
ServiceActivatingHandler(Object) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, Method) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, String) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(MessageProcessor<T>) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of handling a message or message payload.
ServiceActivatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @ServiceActivator.
ServiceActivatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
ServiceActivatorFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating ServiceActivatingHandler instances.
ServiceActivatorFactoryBean() - Constructor for class org.springframework.integration.config.ServiceActivatorFactoryBean
 
ServiceActivatorParser - Class in org.springframework.integration.config.xml
Parser for the <service-activator> element.
ServiceActivatorParser() - Constructor for class org.springframework.integration.config.xml.ServiceActivatorParser
 
ServiceUnavailableException - Exception in org.springframework.integration.ws
The WebServiceException extension to indicate that the server endpoint is temporary unavailable.
ServiceUnavailableException(String) - Constructor for exception org.springframework.integration.ws.ServiceUnavailableException
 
ServiceUnavailableException(String, Throwable) - Constructor for exception org.springframework.integration.ws.ServiceUnavailableException
 
Session<F> - Interface in org.springframework.integration.file.remote.session
Common abstraction for a Session with a remote File system.
session(Session) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
A Java Mail Session to use.
session(Session) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Provide the Java Mail Session to use.
SESSION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
SESSION_TRANSACTED - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
SESSION_TRANSACTED_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
 
sessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
A session acknowledgement mode.
sessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
sessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
sessionAcknowledgeModeName(String) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
A session acknowledgement mode name.
SessionCallback<F,T> - Interface in org.springframework.integration.file.remote
Callback invoked by RemoteFileOperations.execute() - allows multiple operations on a session.
SessionCallbackWithoutResult<F> - Interface in org.springframework.integration.file.remote
Simple convenience implementation of SessionCallback for cases where no result is returned.
SessionClosedEvent - Class in org.springframework.integration.ftp.server
An event emitted when a session is closed.
SessionClosedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionClosedEvent
 
SessionClosedEvent - Class in org.springframework.integration.sftp.server
An event emitted when a session is closed.
SessionClosedEvent(ServerSession) - Constructor for class org.springframework.integration.sftp.server.SessionClosedEvent
 
sessionFactory - Variable in class org.springframework.integration.file.remote.RemoteFileTemplate
The SessionFactory for acquiring remote file Sessions.
SessionFactory<F> - Interface in org.springframework.integration.file.remote.session
Factory for acquiring Session instances.
SessionFactoryLocator<F> - Interface in org.springframework.integration.file.remote.session
A factory returning a SessionFactory based on some key.
SessionFactoryMapBuilder<T> - Class in org.springframework.integration.file.remote.session
A MapBuilder to producer a map that maps objects to SessionFactorys.
SessionFactoryMapBuilder() - Constructor for class org.springframework.integration.file.remote.session.SessionFactoryMapBuilder
 
SessionOpenedEvent - Class in org.springframework.integration.ftp.server
An event emitted when a session is opened.
SessionOpenedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionOpenedEvent
 
SessionOpenedEvent - Class in org.springframework.integration.sftp.server
An event emitted when a session is opened.
SessionOpenedEvent(ServerSession, int) - Constructor for class org.springframework.integration.sftp.server.SessionOpenedEvent
 
sessions - Variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
sessionTransacted(boolean) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
A session transaction mode.
sessionTransacted(Boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
sessionTransacted(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
Configure transactional sessions for both the JmsTemplate (sends and polled receives) and DefaultMessageListenerContainer (message-driven receives).
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
 
SET_MODIFIED - Static variable in class org.springframework.integration.file.FileHeaders
 
setAcceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setAckAddress(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAckCounter(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setAckDeferred(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
setAckDeferred(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
setAckDiscarded(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
A boolean flag to indicate if FilteringMessageListenerAdapter should acknowledge discarded records or not.
setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAcknowledged(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setActive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setActivePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Deprecated.
Set the poll period when messages are returned.
setActivePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
Set the poll period when messages are returned.
setAddContentTypeHeader(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Set to true to add a content type header; default false.
setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Optional method allowing you to set additional flags.
setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.ImapMailReceiver
 
setAdditionalPropertiesCallback(Function<NamedComponent, Map<String, Object>>) - Method in class org.springframework.integration.graph.IntegrationGraphServer
Specify a callback Function to be called against each NamedComponent to populate additional properties to the target IntegrationNode.
setAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
setAdviceChain(Advice[]) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the advice chain to be configured within an AbstractReplyProducingMessageHandler to advise just this local endpoint.
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setAdviceMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for AdviceMessage.
setAfterCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterRollbackChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterRollbackExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAge(long, TimeUnit) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
Set the age that files have to be before being passed by this filter.
setAge(Duration) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
Set the age that files have to be before being passed by this filter.
setAge(long) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
Set the age that files have to be before being passed by this filter.
setAllowCredentials(Boolean) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setAllowedHeaders(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setAllowedOrigins(String...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
Configure allowed Origin header values.
setAllowedPatterns(String...) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
Set simple patterns for allowable packages/classes for deserialization.
setAllowedPatterns(String...) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
When using a AllowListDeserializingConverter (the default) add patterns for packages/classes that are allowed to be deserialized.
setAllowUnknownKeys(boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
When no UserInfo has been provided, set to true to unconditionally allow connecting to an unknown host or when a host's key has changed (see knownHosts).
setAlwaysAcceptDirectories(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
Set to true to indicate that the pattern should not be applied to directories.
setAlwaysAcceptDirectories(boolean) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
Set to true so that filters that support this feature can unconditionally pass directories; default false.
setAlwaysUseResultFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Specify whether to always use result factory even for directly supported payload types
setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
If true always delegate to the SourceFactory.
setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Specify whether to always use source factory even for directly supported payload types.
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.
setAppendNewLine(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setAppendNewLine(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
If 'true' will append a new-line after each write.
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.graph.IntegrationGraphServer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
setApplicationName(String) - Method in class org.springframework.integration.graph.IntegrationGraphServer
Set the application name that will appear in the 'contentDescriptor' under the 'name' key.
setApplySequence(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether to apply the sequence number and size headers to the messages prior to invoking the subscribed handlers.
setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether to apply sequence numbers to the messages prior to sending to the handlers.
setApplySequence(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
setApplySequence(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether to apply the sequence number and size headers to the messages prior to sending to the recipient channels.
setApplySequence(boolean) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Set the applySequence flag to the specified value.
setArgumentsSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
setArgumentsStrategy(ArgumentsStrategy) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
setAsMap(boolean) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
Set false will leave the payload as the original complete syslog.
setAsync(Boolean) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Currently only exposed on the service activator namespace.
setAsync(boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Allow async replies.
setAsync(boolean) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Set to true if you don't want to block when sending messages.
setAsyncEvents(boolean) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
When MqttPahoMessageHandler.setAsync(boolean) is true, setting this to true enables publication of MqttMessageSentEvent and MqttMessageDeliveredEvent to be emitted.
setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the executor for use when the gateway method returns Future or ListenableFuture.
setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the name of the attribute to be retrieved.
setAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setAuthValue(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setAutoAck(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Set whether or not acknowledge message read in the Consumer Group.
setAutoCloseFolder(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Configure a boolean flag to close the folder automatically after a fetch (default) or populate an additional IntegrationMessageHeaderAccessor.CLOSEABLE_RESOURCE message header instead.
setAutoCloseFolder(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify whether to create the source directory automatically if it does not yet exist upon initialization.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to create the destination directory automatically if it does not yet exist upon initialization.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Determine whether the remote directory should automatically be created when sending files to the remote system.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
A boolean flag to indicate automatically create the directory or not.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Determine whether the remote directory should automatically be created when sending files to the remote system.
setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
A boolean flag to identify if local directory should be created automatically.
setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
setAutoReceipt(boolean) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setAutoStartup(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setAutoStartup(Boolean) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setAutoStartup(boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setAutoStartup(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
Set the auto startup.
setAutoStartup(boolean) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
setAutoStartup(boolean) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setAutoStartup(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setAutoStartup(boolean) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setAutoStartup(boolean) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
setAutoStartup(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
setAutoStartup(boolean) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
setBackendPort(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Specify a fixed port for backend socket of the proxy.
setBackendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Provide a Consumer to configure a proxy backend socket with arbitrary options, like security.
setBacklog(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setBacklog(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
The number of sockets in the connection backlog.
setBaseDirectory(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
Set the location for the properties file.
setBasename(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set a single basename, following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
setBasenames(String[]) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set an array of basenames, each following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
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.
setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter to use with a batch-based consumer.
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
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.interceptor.WireTap
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.MessagingTemplate
Overridden to set the destination resolver to a integrationChannelResolver bean.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.filters.ExpressionFileListFilter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.BeanNameMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.LambdaMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Allows to set the optional BeanFactory which is used to add a BeanResolver to the StandardEvaluationContext.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationJmxAttributeSource
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.test.context.MockIntegrationContext
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
Specify a BeanFactory in order to enable resolution via @beanName in the expression.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
setBeanName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanName(String) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
setBeanName(String) - Method in class org.springframework.integration.channel.NullChannel
 
setBeanName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
setBeanName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setBeanName(String) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setBeanName(String) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
setBeanName(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
setBeanName(String) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
setBeanName(String) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setBeanName(String) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
setBeforeCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setBeforeCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setBindFunction(BiFunction<DatabaseClient.GenericExecuteSpec, ?, DatabaseClient.GenericExecuteSpec>) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Set a BiFunction which is used to bind parameters into the update query.
setBindPort(int) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Configure a port for TCP protocol binding via ZMQ.Socket.bind(String).
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.
setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Set to true to bind the source consumer record in the header named IntegrationMessageHeaderAccessor.SOURCE_DATA.
setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set to true to bind the source consumer record in the header named IntegrationMessageHeaderAccessor.SOURCE_DATA.
setBodyExtractor(BodyExtractor<?, ClientHttpResponse>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Specify a BodyExtractor as an alternative to the expectedResponseType to allow to get low-level access to the received ClientHttpResponse.
setBoundaryTrigger(Predicate<Message<?>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Configure a Predicate for messages to determine a window boundary in the Flux.windowUntil(java.util.function.Predicate<T>) operator.
setBufferSize(Integer) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setBufferSize(int) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the buffer size to use while writing to files; default 8192.
setBufferSize(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setBusyWaitMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Set a BytesMessageMapper to use when mapping byte[].
setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Set a BytesMessageMapper to use when mapping byte[].
setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setCacheEntries(Map<String, String>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
setCacheEntryExpressions(Map<Expression, Expression>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
 
setCacheLevel(Integer) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setCacheLevel(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setCacheLevelName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setCacheManager(CacheManager) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure a common CacheManager if some CacheOperation comes without it.
setCacheOperations(CacheOperation...) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure a set of CacheOperation which are going to be applied to the AbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message) method via IntegrationCacheAspect.
setCacheResolver(CacheResolver) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure a common CacheResolver if some CacheOperation comes without it.
setCacheSeconds(int) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the number of seconds to cache loaded properties files.
setCancelIdleInterval(long) - Method in class org.springframework.integration.mail.ImapMailReceiver
IDLE commands will be terminated after this interval; useful in cases where a connection might be silently dropped.
setCandidate(Candidate) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
Configure a Candidate for leader election.
setCaseSensitive(boolean) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Set to true to make the header name pattern match case sensitive.
setCaseSensitive(boolean) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Specify whether comparison of value returned by XPathExpression to test value should be case sensitive.
setChannel(MessageChannel) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
setChannelConnectTimeout(Duration) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Set the connect timeout.
setChannelConnectTimeout(Duration) - Method in class org.springframework.integration.sftp.session.SftpSession
Set the connect timeout.
setChannelKeyFallback(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
When true (default), if a resolved channel key does not exist in the channel map, the key itself is used as the channel name, which we will attempt to resolve to a channel.
setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setChannelMapping(String, String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Add a channel mapping from the provided key to channel name.
setChannelMapping(String, String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
setChannelMapping(String, String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Add a channel mapping from the provided key to channel name.
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Provide mappings from channel keys to channel names.
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
setChannelMappings(Map<String, String>) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide mappings from channel keys to channel names.
setChannelMessageStoreQueryProvider(ChannelMessageStoreQueryProvider) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Sets the database specific ChannelMessageStoreQueryProvider to use.
setChannelName(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setChannelName(String) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the handler's channel resolver.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the channels for this router.
setChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setCharset(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setCharset(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the charset name to use when writing a File from a String-based Message payload.
setCharset(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the charset to use when converting String payloads to bytes as the content of the remote file.
setCharset(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Set the charset to use when converting String payloads to bytes as the content of the remote file.
setCharset(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the charset to use when converting String payloads to bytes as the content of the remote file.
setCharset(Charset) - Method in class org.springframework.integration.file.splitter.FileSplitter
Set the charset to be used when reading the file, when something other than the default charset is required.
setCharset(String) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
Set the charset name to use when copying the File to a String.
setCharset(Charset) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
Sets the character set used for writing form data.
setCharset(String) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify the charset name to use for converting String-typed payloads to bytes.
setCharset(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Set the charset to use when converting outbound String messages to byte[].
setCharset(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setCharset(String) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
Specify the name of the Charset to use when converting from bytes.
setCharset(String) - Method in class org.springframework.integration.syslog.RFC5424MessageConverter
 
setChmod(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setChmod(int) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the file permissions after uploading, e.g.
setChmod(int) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the file permissions after uploading, e.g.
setChmod(int) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Set the file permissions after uploading, e.g.
setChmodOctal(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
String setter for Spring XML convenience.
setChmodOctal(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
String setter for Spring XML convenience.
setChmodOctal(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
String setter for Spring XML convenience.
setCipherSuites(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setClassifier(Classifier<? super Throwable, Boolean>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
setClearOnFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
If set to true the EntityManager.clear() will be called, and only if the EntityManager.flush() was called after performing persistence operations.
setClient(CuratorFramework) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
setClientId(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setClientLibraryUrl(String) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setClientMode(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
ACTIVE_LOCAL_DATA_CONNECTION_MODE = 0
A constant indicating the FTP session is expecting all transfers to occur between the client (local) and server and that the server should connect to the client's data port to initiate a data transfer.
setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
setClientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Configure a ClientRSocketConnector for client side requests based on the connection provided by the ClientRSocketConnector.getRequester().
setClientRSocketKeyStrategy(BiFunction<Map<String, Object>, DataBuffer, Object>) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Configure a strategy to determine a key for the client RSocketRequester connected.
setClientRSocketKeyStrategy(BiFunction<Map<String, Object>, DataBuffer, Object>) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Configure a BiFunction to extract a key for mapping connected RSocketRequesters.
setClientVersion(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Allows you to set the client version property.
setCloseOnRefresh(boolean) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
When using a shared connection singleUse is false, set this to true to close the old shared connection after a refresh.
setCloseStreamAfterSend(boolean) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Set to true to close the connection ouput stream after sending without closing the connection.
setCloseTimeout(Duration) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the close timeout - default 30 seconds.
setCodecConfigurer(ServerCodecConfigurer) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
A ServerCodecConfigurer for the request readers and response writers.
setCollection(String) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
Specify a collection name to track change events from.
setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Sets the SpEL Expression that should resolve to a collection name used by the Query.
setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Set the SpEL Expression that should resolve to a collection name used by the Query.
setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
Sets the SpEL Expression that should resolve to a collection name used by MongoOperations to store data
setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
Set a SpEL Expression that should resolve to a collection name used by ReactiveMongoOperations to store data
setCollectionNameExpressionString(String) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Sets the collection type for this handler as per RedisCollectionFactoryBean.CollectionType.
setCombineFunction(Function<Flux<Message<?>>, Mono<Message<?>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Configure a transformation Function to apply for a Flux window to emit.
setCommandExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
setCommandExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setComparator(Comparator<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set a comparator to sort the retrieved list of F (the Type that represents the remote file) prior to applying filters and max fetch size.
setCompareValues(BiPredicate<String, String>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
Set a BiPredicate to compare old and new values in the metadata store for the key.
setCompilerConfiguration(CompilerConfiguration) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Specify the CompilerConfiguration options to customize the Groovy script compilation.
setCompileStatic(boolean) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Specify the boolean flag to indicate if the GroovyClassLoader's compiler should be customised for the CompileStatic hint for the provided script.
setComplete(boolean) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Set the completion timeout for operations.
setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Set the completion timeout for async operations.
setComponentName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Sets the name of the handler component.
setComponentName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Sets the name of this component.
setComponentName(String) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setComponentName(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setComponentName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setComponentName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setComponentNamePatterns(String[]) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
The patterns for which components will be tracked; default '*' (all trackable components).
setComponentNamePatterns(String[]) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Set the array of simple patterns for component names to register (defaults to '*').
setComponentNamePatternsSet(Set<String>) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
The patterns for which components will be tracked; default '*' (all trackable components).
setComponentNamePatternsString(String) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
A comma-delimited list of patterns for which components will be tracked; default '*' (all trackable components).
setComponentType(String) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
setComponentType(String) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setConcurrency(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setConfig(FTPClientConfig) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
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.
setConnectHeaders(StompHeaders) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setConnectionConfiguration(XMPPTCPConnectionConfiguration) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
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
 
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
setConnectionFactory(AbstractClientConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
Sets the client or server connection factory; for this (an inbound adapter), if the factory is a client connection factory, the sockets are owned by a sending channel adapter and this adapter is used to receive replies.
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
Sets the client or server connection factory; for this (an outbound adapter), if the factory is a server connection factory, the sockets are owned by a receiving channel adapter and this adapter is used to send replies.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS ConnectionFactory that this gateway should use.
setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
setConnectionOptions(MqttConnectOptions) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
Set the preconfigured MqttConnectOptions.
setConnectionTest(Predicate<TcpConnectionSupport>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Set a Predicate that will be invoked to test a new connection; return true to accept the connection, false the reject.
setConnectionTimeout(int) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
Set the connection timeout in seconds; default: 10.
setConnectionWaitTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setConnectorConfigurer(RSocketConnectorConfigurer) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Callback to configure the ClientRSocketFactory directly.
setConnectTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Set the connect timeout for the socket.
setConnectTimeout(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setConnectTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Set the connection timeout in seconds.
setConnectTimeout(long) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
Specify the the timeout in milliseconds to wait for the STOMP session establishment.
setConnectUrl(String) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
Configure a connection to the ZeroMQ proxy with the pair of ports over colon for proxy frontend and backend sockets.
setConnectUrl(String) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Configure an URL for ZMQ.Socket.connect(String).
setConsumeDelay(Duration) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
Specify a Duration to delay consumption when no data received.
setConsumeDelay(Duration) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Specify a Duration to delay consumption when no data received.
setConsumerGroup(String) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Set the name of the Consumer Group.
setConsumerName(String) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Set the name of the consumer.
setConsumersPerQueue(Integer) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setConsumerStopAction(ConsumerStopAction) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
Set the consumer stop action.
setConsumes(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setContainerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setContentType(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Set the content type header value to add to inbound messages when addContentTypeHeader is true.
setContentType(String) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
Sets the content-type header value
setControlEncoding(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setConversionService(ConversionService) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setConversionService(ConversionService) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
setConversionService(ConversionService) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
Specify the ConversionService to use when trying to convert to requested type.
setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setConverter(MqttMessageConverter) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
setConverter(MessageConverter) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the message converter to use; if this is provided, the adapter qos and retained settings are ignored.
setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
A MessageConverter to convert the byte array payload of the underlying UDP/TCP message to a Spring Integration message with decoded payload and headers; default is DefaultMessageConverter.
setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
Specify the converter to use.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.XPathRouter
Specify the Converter to use when converting payloads prior to XPath evaluation.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
Specify the converter used to convert payloads prior to XPath testing.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
Specify the Converter to use when converting payloads prior to validation.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Specify the XmlPayloadConverter to use when converting a Message payload prior to XPath evaluation.
setConvertExceptions(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
Flag to determine if conversion and writing out of message handling exceptions should be attempted (default false, in which case they will simply be re-thrown).
setCopyOnGet(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
Set to false to disable copying the group in SimpleMessageStore.getMessageGroup(Object).
setCorrelationId(Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setCorrelationId(Object) - Method in class org.springframework.integration.support.MessageBuilder
 
setCorrelationKey(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide the name of a JMS property that should be copied from the request Message to the reply Message.
setCorrelationKey(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide the name of a JMS property that should hold a generated UUID that the receiver of the JMS Message would expect to represent the CorrelationID.
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the CorrelationStrategy to be used to determine the correlation key for incoming messages
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Configure a CorrelationStrategy to determine a group key from the incoming messages.
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setCreateConsumerGroup(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Create the Consumer Group if and only if it does not exist.
setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setCriteriaExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Set a SpEL expression to evaluate a Criteria for query to execute.
setCrossOrigin(CrossOrigin) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Set the CrossOrigin to permit cross origin requests for this endpoint.
setCustomConverters(Object...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
Configure a set of converters to use in the MappingMongoConverter.
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Sets a GroovyObjectCustomizer for this processor.
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Sets a GroovyObjectCustomizer for this processor.
setDataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
Configure a MimeType for data exchanging.
setDataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
The JDBC DataSource to use when interacting with the database.
setDataTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Set the (socket option) timeout on the data connection.
setDatatypes(Class<?>...) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the Message payload datatype(s) supported by this channel.
setDecodeFluxAsUnit(boolean) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Configure an option to decode an incoming Flux as a single unit or each its event separately.
setDecoratorFactories(WebSocketHandlerDecoratorFactory...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
Configure one or more factories to decorate the handler used to process WebSocket messages.
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.core.MessagingTemplate
Invokes setDefaultDestination(MessageChannel) - provided for backward compatibility.
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
A channel bean name to be used as default for publishing.
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
Set the default channel where Messages should be sent if the annotation itself does not provide a channel.
setDefaultDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the default delay in milliseconds.
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.
setDefaultDomain(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
The JMX domain to use for MBeans registered.
setDefaultEncoding(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the default charset to use for parsing properties files.
setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setDefaultErrorChannelName(String) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
Specify the bean name of default error channel for this error handler.
setDefaultLoggingEnabled(boolean) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
Disable all logging in the normal message flow in framework components.
setDefaultMultipartCharset(String) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
Specify the default charset name to use when converting multipart file content into Strings if the multipart itself does not provide a charset.
setDefaultNotificationType(String) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Specify a dot-delimited String representing the Notification type to use by default when no explicit Notification mapper has been configured.
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the default channel where Messages should be sent if channel resolution fails to return any channels.
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
 
setDefaultOverwrite(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setDefaultPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the default JMS priority to use when sending request Messages with no IntegrationMessageHeaderAccessor.PRIORITY header.
setDefaultQos(int) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the qos for messages if the qosExpression evaluates to null.
setDefaultReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default reply channel.
setDefaultReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default reply channel bean name.
setDefaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the default reply destination to send reply messages to.
setDefaultReplyQueueName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply queue to send reply messages to.
setDefaultReplyTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for receiving reply messages.
setDefaultReplyTimeoutExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set an expression to be evaluated to determine the default timeout value for receiving reply messages.
setDefaultReplyTimeoutExpressionString(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set an expression to be evaluated to determine the default timeout value for receiving reply messages.
setDefaultReplyTo(String) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
The defaultReplyTo address with the form
 (exchange)/(routingKey)
setDefaultReplyTopicName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply topic to send reply messages to.
setDefaultRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel.
setDefaultRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel bean name.
setDefaultRequestTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for sending request messages.
setDefaultRequestTimeoutExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set an expression to be evaluated to determine the default timeout value for sending request messages.
setDefaultRequestTimeoutExpressionString(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set an expression to be evaluated to determine the default timeout value for sending request messages.
setDefaultRetained(boolean) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the retained boolean for messages if the retainedExpression evaluates to null.
setDefaultTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Set the (socket option) timeout on the command socket.
setDefaultTopic(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the topic to which the message will be published if the topicExpression evaluates to `null`.
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.
setDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setDelayedAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.DelayHandler
Specify the List<Advice> to advise DelayHandler.ReleaseMessageHandler proxy.
setDelayedMessageErrorChannel(MessageChannel) - Method in class org.springframework.integration.handler.DelayHandler
Set a message channel to which an ErrorMessage will be sent if sending the released message fails.
setDelayedMessageErrorChannelName(String) - Method in class org.springframework.integration.handler.DelayHandler
Set a message channel name to which an ErrorMessage will be sent if sending the released message fails.
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.
setDelayExpression(Expression) - Method in class org.springframework.integration.handler.DelayHandler
Specify the Expression that should be checked for a delay period (in milliseconds) or a Date to delay until.
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.
setDelayExpressionString(String) - Method in class org.springframework.integration.handler.DelayHandler
Specify the Expression that should be checked for a delay period (in milliseconds) or a Date to delay until.
setDelayWhenEmpty(Duration) - Method in class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
Configure a Duration to delay next pull request when the previous one was empty.
setDeleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
If set to 'true', the retrieved objects are deleted from the database upon being polled.
setDeleteFiles(boolean) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
Specify whether to delete the File after transformation.
setDeleteInBatch(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
If not set, this property defaults to false, which means that deletion occurs on a per object basis if a collection of entities is being deleted.
setDeleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set to true to enable deletion of remote files after successful transfer.
setDeleteSourceFiles(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDeleteSourceFiles(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to delete source Files after writing to the destination directory.
setDelimiters(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setDelimiters(String) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
Set delimiters to use for tokenizing String values.
setDeliveryModeExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify a SpEL expression to evaluate a deliveryMode for the JMS message to send.
setDeliveryModeExpressionString(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify a SpEL expression to evaluate a deliveryMode for the JMS message to send.
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set whether message delivery should be persistent or non-persistent, specified as a boolean value ("true" or "false").
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
A converter for deserializing byte arrays to messages.
setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
A converter for deserializing byte arrays to messages.
setDeserializer(Deserializer<Object>) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
setDestination(Destination) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestination(Destination) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setDestination(Destination) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setDestination(String) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
setDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setDestinationExpression(Expression) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
setDestinationName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestinationName(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setDestinationName(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the DestinationResolver that should be used to resolve reply destination names for this listener.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide the DestinationResolver to use when resolving either a 'requestDestinationName' or 'replyDestinationName' value.
setDirectory(File) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setDirectory(File) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDirectory(File) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify the input directory.
setDirectoryExpression(Expression) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Set the channel to which late arriving trigger messages are sent.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.filter.MessageFilter
Specify a channel where rejected Messages should be sent.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify a channel where rejected Messages should be sent.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Specify a channel where rejected Messages should be sent.
setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Set the name of the channel to which late arriving trigger messages are sent.
setDiscardChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setDiscardChannelName(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setDiscardChannelName(String) - Method in class org.springframework.integration.filter.MessageFilter
 
setDiscardChannelName(String) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify a channel name where rejected Messages should be sent.
setDiscardChannelName(String) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Specify a channel bean name (resolved to MessageChannel lazily) where rejected Messages should be sent.
setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.filter.MessageFilter
Set to 'true' if you wish the discard processing to occur within any request handler advice applied to this filter.
setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Set the completion timeout when disconnecting.
setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
Set the completion timeout when disconnecting.
setDisconnectDelay(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setDomainType(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
Specify an object type to convert an event body to.
setDurable(boolean) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
setDurableSubscriptionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDuration(Duration) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Set the duration.
setDynamicChannelLimit(int) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Set a limit for how many dynamic channels are retained (for reporting purposes).
setEmbeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
setEmbeddedPartsAsBytes(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setEnableDaemonThread(Boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
If true, all threads will be daemon threads.
setEnableStatusReader(boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
If false, thread for capturing stderr will not be started and stderr output will be ignored
setEnableStatusReader(boolean) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
If false, thread for capturing stderr will not be started and stderr output will be ignored
setEncodeUri(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
setEncodeUri(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
setEncoding(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setEncoding(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
Encoding to use when storing data in ZooKeeper
setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set the encoding mode to use.
setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
 
setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Set the encoding mode to use.
setEnd(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setEnd(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
If true, tail from the end of the file, otherwise include all lines from the beginning.
setEndpoints(IntegrationRSocketEndpoint...) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
Configure IntegrationRSocketEndpoint instances for mapping and handling requests.
setEntityClass(Class<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Sets the class type which is being used for retrieving entities from the database.
setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Allows you to set the type of the entityClass that will be passed to the MongoTemplate.find(Query, Class) or MongoTemplate.findOne(Query, Class) method.
setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Allow you to set the type of the entityClass that will be passed to the ReactiveMongoTemplate.find(Query, Class) or ReactiveMongoTemplate.findOne(Query, Class) method.
setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
setEnvironment(Environment) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the content enricher's error channel to allow the error handling flow to return of an alternative object to use for enrichment if exceptions occur in the downstream flow.
setErrorChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setErrorChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setErrorChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setErrorChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setErrorChannelName(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setErrorChannelName(String) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
Specify a MessageChannel bean name for async error processing.
setErrorChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setErrorChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setErrorCode(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The error code to use to signal an error in the message handling.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Provide an ErrorHandler strategy for handling Exceptions that occur downstream from this channel.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
setErrorHandler(CacheErrorHandler) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Set the CacheErrorHandler instance to use to handle errors thrown by the cache provider.
setErrorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the ResponseErrorHandler for the underlying RestTemplate.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setErrorMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for ErrorMessage.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
Set the error message strategy to use for returned (or negatively confirmed) messages.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the error message strategy implementation to use when sending error messages after send failures.
setErrorOnTimeout(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
If errorOnTimeout is true, construct an instance that will send an ErrorMessage with a MessageTimeoutException payload to the error channel if a reply is expected but none is received.
setErrorOnTimeout(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setErrorOnTimeout(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setErrorsKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The key used to expose Errors in the core, in the case that message handling fails.
setEvaluateAsString(boolean) - Method in class org.springframework.integration.xml.router.XPathRouter
 
setEvaluationContext(StandardEvaluationContext) - Method in class org.springframework.integration.transformer.DecodingTransformer
 
setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Specify the expected XPathEvaluationType.
setEventTypes(Class<?>...) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
Set the list of event types (classes that extend ApplicationEvent) that this adapter should send to the message channel.
setExceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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
 
setExcludedInboundStandardResponseHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide header names from the list of standard headers that should be suppressed when mapping inbound endpoint response headers.
setExcludedOutboundStandardRequestHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide header names from the list of standard headers that should be suppressed when mapping outbound endpoint request headers.
setExecutor(Executor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
setExecutor(Executor) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
Set the Executor, where is not provided then a default of cached thread pool Executor will be used.
setExecutorService(ExecutorService) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Set the ExecutorService, where is not provided then a default of single thread Executor will be used.
setExistsMode(FtpRemoteFileTemplate.ExistsMode) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify the expected response type for the REST request otherwise the default response type is ResponseEntity and will be returned as a payload of the reply Message.
setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Specify an response type for the RSocket response.
setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify the Expression to determine the type for the expected response The returned value of the expression could be an instance of Class or String representing a fully qualified class name.
setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Specify an Expression to determine the type for the RSocket response.
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Set the result type expected from evaluation of the expression.
setExpectMessage(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
When data is retrieved from the Redis queue, does the returned data represent just the payload for a Message, or does the data represent a serialized Message?.
setExpectReply(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
Set to true if this endpoint is a gateway.
setExpectReply(boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setExpectReply(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether a reply Message is expected.
setExpectReply(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify whether a reply Message is expected.
setExpectReply(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether a JMS reply Message is expected.
setExpectReply(boolean) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify whether a reply Message is expected.
setExpectReply(boolean) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
Specify whether the gateway should be expected to return a reply.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
This parameter indicates that only one result object shall be returned from the Stored Procedure/Function Call.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
This parameter indicates that only one result object shall be returned from the Stored Procedure/Function Call.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
This parameter indicates that only one result object shall be returned as a result from the executed JPA operation.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Allows you to manage which find* method to invoke on MongoTemplate.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Allow you to manage which find* method to invoke on ReactiveMongoTemplate.
setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setExpectSingleResult(boolean) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
The flag to manage which find* method to invoke on R2dbcEntityOperations.
setExpirationDate(Long) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setExpirationDate(Long) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpireDuration(Duration) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Configure a Duration how often to clean up old orphaned groups from the store.
setExpireDuration(Duration) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a Duration how often to run a scheduled purge task.
setExpireDurationMillis(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Configure a Duration (in millis) how often to clean up old orphaned groups from the store.
setExpireDurationMillis(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
Will set the 'expireGroupsUponCompletion' flag.
setExpireGroupsUponCompletion(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Expire (completely remove) a group if it is completed due to timeout.
setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
Overridden to false for a resequencer so late messages are immediately discarded rather than waiting for the next timeout
setExpireGroupsUponTimeout(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireOnDestroy(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Flag to indicate that the stores should be expired when this component is destroyed (i.e.
setExpireTimeout(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Configure a timeout in milliseconds for purging old orphaned groups from the store.
setExpireTimeout(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a timeout for old groups in the store to purge.
setExpiryCallbacks(Collection<MessageGroupStore.MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Convenient injection point for expiry callbacks in the message store.
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether explicit QoS settings are enabled (deliveryMode, priority, and timeToLive).
setExplicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether explicit QoS should be enabled for replies (for timeToLive, priority, and deliveryMode settings).
setExposeCaptureSocket(boolean) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Whether to bind and expose a capture socket for the proxy data.
setExposedHeaders(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setExposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setExposeListenerSession(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setExpression(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set a SpEL expression to use.
setExpression(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
Specify an expression to be evaluated against the Message in order to generate a file name.
setExpression(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
setExpression(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
 
setExpressionString(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set a SpEL expression to use.
setExtensionProvider(ExtensionElementProvider<? extends ExtensionElement>) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
Specify an ExtensionElementProvider to build an ExtensionElement for the Stanza.addExtension(ExtensionElement) instead of body.
setExtractBody(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
Configure this channel adapter to build a Message to produce with a payload based on a ChangeStreamEvent.getBody() (by default) or use a whole ChangeStreamEvent as a payload.
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
 
setExtractPayload(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify whether the outbound message's payload should be extracted when preparing the request body.
setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
The flag to indicate if we should extract body from JMS Message, or use the received JMS Message as Message payload.
setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify whether the payload should be extracted from each integration Message to be used as the JMS Message body.
setExtractPayload(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Configure this channel adapter to extract or not value from the Record.
setExtractPayload(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
Set to true to extract the payload; otherwise the entire message is sent.
setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
A flag to return the whole WebServiceMessage or build payload based on WebServiceMessage and populated headers according headerMapper configuration.
setExtractPayload(boolean) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
Specify whether the source Message's payload should be extracted prior to marshalling.
setExtractPayloadElements(boolean) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Sets the flag signifying that if the payload is a "multivalue" (i.e., Collection or Map), it should be saved using addAll/putAll semantics.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify whether only the reply Message's payload should be passed in the response.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the Spring Integration reply Message's payload should be extracted prior to converting into a JMS Message.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property describes what to do with a JMS reply Message.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the JMS request Message's body should be extracted prior to converting into a Spring Integration Message.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property describes how a JMS Message should be generated from the Spring Integration Message.
setFailover(boolean) - Method in class org.springframework.integration.channel.DirectChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.channel.ExecutorChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Specify whether this dispatcher should failover when a single MessageHandler throws an Exception.
setFailureChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel to which to send the ErrorMessage after evaluating the failure expression.
setFailureChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel name to which to send the ErrorMessage after evaluating the failure expression.
setFallbackToSystemLocale(boolean) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set whether to fall back to the system Locale if no files for a specific Locale have been found.
setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setFile(File) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setFile(File) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
The name of the file you wish to tail.
setFileDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setFileEncodings(Properties) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set per-file charsets to use for parsing properties files.
setFileExistsMode(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Will set the FileExistsMode that specifies what will happen in case the destination exists.
setFileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Determine the action to take when using GET and MGET operations when the file already exists locally, or PUT and MPUT when the file exists on the remote system.
setFileInfoJson(boolean) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Set to false to add the FileHeaders.REMOTE_FILE_INFO header to the raw FileInfo.
setFileName(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
Set the name of the properties file in PropertiesPersistingMetadataStore.setBaseDirectory(String).
setFileNameExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the file name expression to determine the full path to the remote file.
setFileNameExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the file name expression to determine the full path to the remote file when retrieving a file using the RemoteFileTemplate.get(Message, InputStreamCallback) method, with the message being the root object of the evaluation.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Provide the FileNameGenerator strategy to use when generating the destination file's name.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
setFilenamePattern(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFilenameRegex(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFileType(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
File types defined by FTP constants: FTP.ASCII_FILE_TYPE FTP.EBCDIC_FILE_TYPE FTP.BINARY_FILE_TYPE (DEFAULT) FTP.LOCAL_FILE_TYPE
setFileVisitOptions(FileVisitOption...) - Method in class org.springframework.integration.file.RecursiveDirectoryScanner
The options to configure the traversal.
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
setFilter(FileListFilter<File>) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom filter to be used by this scanner.
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.HeadDirectoryScanner
 
setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Set the filter to be applied to the remote files before transferring.
setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set a FileListFilter to filter remote files.
setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set the filter to be applied to the remote files before transferring.
setFilter(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a NotificationFilter to be passed to the server when registering this listener.
setFilter(CollectionFilter<Resource>) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setFilterHeadersInToMessage(boolean) - Method in class org.springframework.integration.support.converter.MapMessageConverter
By default all headers on Map passed to MapMessageConverter.toMessage(Object, MessageHeaders) will be mapped.
setFilterInRetry(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
The boolean flag to specify the order how RetryingMessageListenerAdapter and FilteringMessageListenerAdapter are wrapped to each other, if both of them are present.
setFirstLineAsHeader(String) - Method in class org.springframework.integration.file.splitter.FileSplitter
Specify the header name for the first line to be carried as a header in the messages emitted for the remaining lines.
setFirstResultExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Set the expression that will be evaluated to get the first result in the query executed.
setFixedRate(boolean) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify whether the periodic interval should be measured between the scheduled start times rather than between actual completion times.
setFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
If set to true the EntityManager.flush() will be called after persistence operation.
setFlushExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Specify a SpEL expression that evaluates to a Boolean to determine whether the producer should be flushed after the send.
setFlushInterval(long) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFlushInterval(long) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the frequency to flush buffers when FileExistsMode.APPEND_NO_FLUSH is being used.
setFlushOnUpdate(boolean) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Determine whether the metadataStore should be flushed on each update (if Flushable).
setFlushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFlushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set a FileWritingMessageHandler.MessageFlushPredicate to use when flushing files when FileExistsMode.APPEND_NO_FLUSH is being used.
setFlushSize(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
If the provided value is greater than 0, then EntityManager.flush() will be called after persistence operations as well as within batch operations.
setFlushWhenIdle(boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFlushWhenIdle(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Determine whether the flushInterval applies only to idle files (default) or whether to flush on that interval after the first write to a previously flushed or new file.
setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setFrontendPort(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Specify a fixed port for frontend socket of the proxy.
setFrontendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Provide a Consumer to configure a proxy frontend socket with arbitrary options, like security.
setFunctions(Map<String, Method>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setFuturesChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the futures channel.
setFuturesChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the futures channel name.
setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
Specify the JpaOutboundGateway mode.
setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setGatherChannel(MessageChannel) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
setGatherTimeout(long) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
setGenericMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for GenericMessage.
setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setGroupCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setGroupId(String) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
Set the group id for the consumer; if not set, the bean name will be used.
setGroupId(Object) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setHalfOpenAfter(long) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
setHandback(Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a handback object to provide context to the listener upon notification.
setHandler(Object) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setHandshakeHandler(HandshakeHandler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
setHandshakeHeaders(WebSocketHttpHeaders) - Method in class org.springframework.integration.stomp.WebSocketStompSessionManager
 
setHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
Set the timeout while waiting for handshake data (in seconds).
setHashMapper(HashMapper<String, ?, ?>) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
setHashMapRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for HashMap.
setHeader(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Set the value for the given header name.
setHeader(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name.
setHeader(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
setHeaderExpressionMap(Map<String, Map<String, String>>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setHeaderExpressions(Map<String, String>) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specifies a Map of SpEL expressions to evaluate in order to generate the Message headers.
setHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
Provide the map of HeaderValueMessageProcessor to evaluate when enriching the target MessageHeaders.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
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 default DefaultAmqpHeaderMapper.inboundMapper().
setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
Set a custom AmqpHeaderMapper for mapping request and reply headers.
setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a JmsHeaderMapper implementation to use when converting between JMS Messages and Spring Integration Messages.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a JmsHeaderMapper implementation for mapping the Spring Integration Message Headers to/from JMS Message properties.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the header mapper to use.
setHeaderMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Set the header mapper; if a header mapper is not provided, the message payload is a MimeMessage, when provided, the headers are mapped and the payload is the MimeMessage content.
setHeaderMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setHeaderMapper(HeaderMapper<StompHeaders>) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
setHeaderMapper(HeaderMapper<StompHeaders>) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
setHeaderName(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
Specify a custom header name to check for the file name.
setHeaderNames(String...) - Method in class org.springframework.integration.support.converter.MapMessageConverter
setHeaders(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setHeaders(HttpHeaders) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
setHeadersFunction(Function<MessageGroup, Map<String, Object>>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
Specify a Function to map MessageGroup into composed headers for output message.
setHeadersFunction(Function<MessageGroup, Map<String, Object>>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setHeadersLast(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setHeadersMap(Map<String, String>) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
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.
setHeaderType(Class<?>) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
setHeartBeatMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setHeartbeatTime(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setHost(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setHost(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setHost(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Set the host; requires the factory to be stopped.
setHost(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setHost(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The url of the host you want connect to.
setHost(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setHostKeyAlias(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Sets the host key alias, used when comparing the host key to the known hosts list.
setHttpMessageCacheSize(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setHttpMethod(HttpMethod) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify the HttpMethod for requests.
setHttpMethodExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Specify the SpEL Expression to determine HttpMethod at runtime.
setIdExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Set the expression that will be evaluated to get the primaryKey for EntityManager.find(Class, Object)
setIdleBetweenTries(Duration) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
Specify a @link Duration} to sleep between lock record insert/update attempts.
setIdleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setIdleEventInterval(long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
How often to emit FileTailingMessageProducerSupport.FileTailingIdleEvents in milliseconds.
setIdleEventInterval(long) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
How often to emit FileTailingMessageProducerSupport.FileTailingIdleEvents in milliseconds.
setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Deprecated.
Set the poll period when messages are not returned.
setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
Set the poll period when messages are not returned.
setIdleReplyContainerTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the target timeout for idle containers, in seconds.
setIdleReplyContainerTimeout(long, TimeUnit) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the target timeout for idle containers.
setIdleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setIdleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setIgnoreColumnMetaData(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
For fully supported databases, the underlying SimpleJdbcCall can retrieve the parameter information for the to be invoked Stored Procedure from the JDBC Meta-data.
setIgnoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Specify whether empty String response payloads should be ignored.
setIgnoreExpressionFailures(boolean) - Method in class org.springframework.integration.handler.DelayHandler
Specify whether Exceptions thrown by DelayHandler.delayExpression evaluation should be ignored (only logged).
setIgnoreFailures(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreFailures(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreHidden(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
Specify whether hidden files shall be ignored.
setIgnoreSendFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setIgnoreSendFailures(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether send failures for one or more of the recipients should be ignored.
setImplicit(boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setImplicitChannel(boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
setImportMetadata(AnnotationMetadata) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
setImportMetadata(AnnotationMetadata) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
 
setInboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setInboundHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide the header names that should be mapped from an HTTP request (for inbound adapters) or HTTP response (for outbound adapters) to a Spring Integration Message's headers.
setInboundHeaderNames(String[]) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
 
setInboundMessageMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setInboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Specify a prefix to be appended to the integration message header name for any JMS property that is being mapped into the MessageHeaders.
setInclusive(boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Set to true to set the length header to include the length of the header in addition to the payload.
setInitialDuration(Duration) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify the delay for the initial execution.
setInitialValue(int) - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
Set the initial ID value.
setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setIntegrationComponents(Map<Object, String>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setInteractionModel(RSocketInteractionModel) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Configure an RSocketInteractionModel for the RSocket request type.
setInteractionModelExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Configure a SpEL expression to evaluate an RSocketInteractionModel for the RSocket request type at runtime against a request message.
setInteractionModels(RSocketInteractionModel...) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Configure a set of RSocketInteractionModel this endpoint is mapped onto.
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
setInterceptors(TcpConnectionInterceptorFactory[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
setInterceptors(HandshakeInterceptor...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
setInterceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setIsFunction(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Indicates whether a Stored Procedure or a Function is being executed.
setIterator(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
The iterator mode: true (default) to return an Iterator for splitting payload, false to return a List.
setJavaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Optional, sets the Authenticator to be used to obtain a session.
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.AbstractMailReceiver
A new Session will be created with these properties (and the JavaMailAuthenticator if provided).
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setJdbcCallOperationsCacheSize(int) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Defines the maximum number of SimpleJdbcCallOperations A value of zero will disable the cache.
setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
The JdbcOperations to use when interacting with the database.
setJpaExecutor(JpaExecutor) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setJpaParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setJpaQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setJsonObjectMapper(JsonObjectMapper<?, ?>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
An JsonObjectMapper to be used for the conversion to/from JSON.
setKey(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Specifies the key for the Redis store.
setKeyExpression(Expression) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure a SpEL expression to evaluate a cache key at runtime against a request message.
setKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Specifies a SpEL Expression to be used to determine the key for the Redis store.
setKeyExpressionString(String) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure an expression in SpEL style to evaluate a cache key at runtime against a request message.
setKeyExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Specifies a SpEL Expression to be used to determine the key for the Redis store.
setKeyFunction(Function<Message<?>, ?>) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
Configure a Function to evaluate a cache key at runtime against a request message.
setKeyManager(KeyManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
Flag to indicate that the update query is an insert with auto-generated keys, which will be logged at debug level.
setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
Flag to indicate that the update query is an insert with auto-generated keys, which will be logged at debug level.
setKeyStoreType(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
Set the key store type.
setKnownHosts(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
setKnownHostsResource(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Specifies the filename that will be used for a host key repository.
setLastModified(long) - Method in interface org.springframework.integration.store.MessageGroup
 
setLastModified(long) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
setLastModifiedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setLastRead(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
setLastReleasedMessageSequenceNumber(int) - Method in interface org.springframework.integration.store.MessageGroup
 
setLastReleasedMessageSequenceNumber(int) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
setLastReleasedSequence(int) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in interface org.springframework.integration.store.MessageGroupStore
Allows you to set the sequence number of the last released Message.
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.SimpleMessageStore
 
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.
setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Specify if the result of the BasicMessageGroupStore.getMessageGroup(Object) should be wrapped to the PersistentMessageGroup - a lazy-load proxy for messages in group Defaults to true.
setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
 
setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
A LeaderEventPublisher option for events from the LeaderInitiator.
setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
setLeaveOpen(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
If true, sockets created by this factory will be reused.
setLeftPush(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
Specify if PUSH operation to Redis List should be LPUSH or RPUSH.
setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setLevel(LoggingHandler.Level) - Method in class org.springframework.integration.handler.LoggingHandler
Set the logging LoggingHandler.Level to change the behavior at runtime.
setLimitForPeriod(int) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Change the limitForPeriod option of the RateLimiterRequestHandlerAdvice.rateLimiter.
setListening(boolean) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setListening(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Provide a LoadBalancingStrategy for this dispatcher.
setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Override the LobHandler that is used to create and unpack large objects in SQL queries.
setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
Override the LobHandler that is used to create and unpack large objects in SQL queries.
setLocalAddress(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setLocalAddress(String) - Method in interface org.springframework.integration.ip.CommonSocketOptions
On a multi-homed system, specifies the ip address of the network interface used to communicate.
setLocalAddress(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setLocalAddress(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Used on multi-homed systems to enforce the server to listen on a specific network address instead of all network adapters.
setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a directory path where remote files will be transferred to.
setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
setLocalDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression to evaluate the directory path to which remote files will be transferred.
setLocalDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression to evaluate the directory path to which remote files will be transferred.
setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression for local files renaming after downloading.
setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set an expression used to determine the local file name.
setLocalFilenameGeneratorExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression for local files renaming after downloading.
setLocalFilenameGeneratorExpressionString(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set an expression used to determine the local file name.
setLocalFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
A FileListFilter used to determine which files will generate messages after they have been synchronized.
setLocker(AbstractFileLockerFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setLocker(FileLocker) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
setLocker(FileLocker) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom locker to be used by this scanner.
setLocker(FileLocker) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setLockHint(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
Specify a row lock hint for the query in the lock-based operations.
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.store.SimpleMessageStore
 
setLogExpression(Expression) - Method in class org.springframework.integration.handler.LoggingHandler
Set an Expression to evaluate a log entry at runtime against the request Message.
setLogExpressionString(String) - Method in class org.springframework.integration.handler.LoggingHandler
Set a SpEL expression string to use.
setLoggerName(String) - Method in class org.springframework.integration.handler.LoggingHandler
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
setLoggingEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
Enable logging or not.
setLookupHost(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
If true, DNS reverse lookup is done on the remote ip address.
setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setManagedName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setManagedName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setManagedName(String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
setManagedName(String) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setManagedType(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setManagedType(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setManagedType(String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
setManagedType(String) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setManualAcks(boolean) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Set the acknowledgment mode to manual.
setMapInboundDeliveryMode(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Map the inbound deliveryMode by using this setter with 'true'.
setMapInboundExpiration(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Map the inbound expiration by using this setter with 'true'.
setMapInboundPriority(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Suppress the mapping of inbound priority by using this setter with 'false'.
setMapKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Sets the expression used as the key for Map and Properties entries.
setMapKeyExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Sets the expression used as the key for Map and Properties entries.
setMapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Provide a custom MethodArgsMessageMapper to map from a MethodArgsHolder to a Message.
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setMapper(ObjectMapper) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
setMapToPayload(boolean) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
setMarshaller(Marshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setMaxAge(long) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setMaxAttempts(int) - Method in class org.springframework.integration.handler.DelayHandler
Set the maximum number of release attempts for when message release fails.
setMaxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setMaxDepth(int) - Method in class org.springframework.integration.file.RecursiveDirectoryScanner
The maximum number of directory levels to visit.
setMaxFetchSize(int) - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
 
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Specify the maximum number of Messages to fetch per call to AbstractMailReceiver.receive().
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setMaxFetchSize(int) - Method in interface org.springframework.integration.support.management.MessageSourceManagement
Set the maximum number of objects the source should fetch if it is necessary to fetch objects.
setMaxMessageSize(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
The maximum supported message size for this serializer.
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
Set the maximum number of messages to receive for each poll.
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxMessagesPerTask(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setMaxNumberOfResults(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Set the max number of results to retrieve from the database.
setMaxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Set the expression for maximum number of results expression.
setMaxRows(Integer) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
The maximum number of rows to query.
setMaxRows(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
The maximum number of rows to query.
setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setMaxSubscribers(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.channel.DirectChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Set the maximum subscribers allowed by this dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxSubscribers(int) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Flag which determines if the default converters should be available after custom converters.
setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
Flag which determines if the default converters should be available after custom converters.
setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
Flag which determines if the default converters should be available after custom converters.
setMessage(Message<?>) - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
setMessage(Message<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
Set the request message (as an alternative to setPayload())
setMessage(Message<?>) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setMessageCodec(SockJsMessageCodec) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setMessageCollectionCallback(MessageCollectionCallback<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
Specify a MessageCollectionCallback to perform against MongoDB collection in the request message context.
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.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the MessageConverter to use when trying to convert to one of this channel's supported datatypes (in order) for a Message whose payload does not already match.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a MessageConverter implementation to use when converting between JMS Messages and Spring Integration Messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a MessageConverter strategy to use for converting the Spring Integration request Message into a JMS Message and for converting the JMS reply Messages back into Spring Integration Messages.
setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the message converter to replace the default MessagingMessageConverter.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Provide a MessageConverter (as an alternative to ZeroMqMessageProducer.messageMapper) for converting a consumed data into a message to produce.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Provide a MessageConverter (as an alternative to ZeroMqMessageHandler.messageMapper) for converting a request message into byte[] for sending into ZeroMq socket.
setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Set the message body converters to use.
setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set a list of HttpMessageConverters to be used by the underlying RestTemplate.
setMessageConverters(List<MessageConverter>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
Set the message converters to use.
setMessageConverters(List<MessageConverter>) - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
Set the message converters to use.
setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Specify the MessageGroupFactory to create MessageGroup object where it is necessary.
setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
Specify the MessageGroupFactory to create MessageGroup object where it is necessary.
setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
Specify the MessageGroupFactory to create MessageGroup object where it is necessary.
setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
A message group store to expire according the other configurations.
setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
 
setMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MessageHeaders.
setMessageIdEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
setMessageListener(WebSocketListener) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
setMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
Provide a BytesMessageMapper to convert to/from messages when send or receive happens on the sockets.
setMessageMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Provide an InboundMessageMapper to convert a consumed data into a message to produce.
setMessageMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Provide an OutboundMessageMapper to convert a request message into byte[] for sending into ZeroMq socket.
setMessageProcessor(MessageProcessor<T>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setMessageRowMapper(MessageRowMapper) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Allows for passing in a custom MessageRowMapper.
setMessageSelector(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageSelector(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Specify a JMS Message Selector expression to use when receiving Messages.
setMessageSelector(String) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
setMessageSender(WebServiceMessageSender) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
setMessageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.handler.DelayHandler
Specify the MessageGroupStore that should be used to store Messages while awaiting the delay.
setMessageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMetadataExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Specify a SpEL expression to evaluate a metadata for the RSocket request as Map<Object, MimeType> against a request message.
setMetadataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
Configure a MimeType for metadata exchanging.
setMetadataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
setMetadataStore(MetadataStore) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
setMetadataStorePrefix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Specify a prefix for keys in metadata store do not clash with other keys in the shared store.
setMethod(Method) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMethod(RequestMethod...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setMethodMetadataMap(Map<String, GatewayMethodMetadata>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMethods(HttpMethod...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
 
setMinAcksForSuccess(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
If acknowledge = true; how many acks needed for success.
setMinimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
By default, when a MessageGroupStoreReaper is configured to expire partial groups, empty groups are also removed.
setMinimumTimeoutForEmptyGroups(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMinSubscribers(int) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
If at least this number of subscribers receive the message, AbstractMessageChannel.send(org.springframework.messaging.Message) will return true.
setMinSubscribers(int) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
If at least this number of subscribers receive the message, BroadcastingDispatcher.dispatch(Message) will return true.
setMissingQueuesFatal(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Allows you to provide a custom MongoConverter used to assist in deserialization data read from MongoDb.
setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
Allow you to provide a custom MongoConverter used to assist in deserialization data read from MongoDb.
setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
Allows you to provide custom MongoConverter used to assist in serialization of data written to MongoDb.
setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
Provide a custom MongoConverter used to assist in serialization of data written to MongoDb.
setMputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
A FileListFilter that runs against the local file system view when using MPUT command.
setMultiAccept(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
Set to false to only accept one connection per iteration over the selector keys.
setMultipartFileReader(MultipartFileReader<?>) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
Specify the MultipartFileReader to use when reading MultipartFile content.
setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Specify the MultipartResolver to use when checking requests.
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).
setMutableMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MutableMessageHeaders.
setMutableMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MutableMessage.
setMutexTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Set an AsyncTaskExecutor to use when establishing (and testing) the connection with Zookeeper.
setName(String) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setName(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
setName(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
 
setName(String) - Method in class org.springframework.integration.test.support.RequestResponseScenario
Set the scenario name (optional)
setNamedQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
A named query can either refer to a named JPQL based query or a native SQL query.
setNativeOptions(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setNativeQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
You can also use native Sql queries to poll data from the database.
setNeedClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setNeedsTest(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Set to true to use a temporary listener for just the first incoming message.
setNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setNewFileCallback(BiConsumer<File, Message<?>>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the callback to use when creating new files.
setNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
How often we clean up closed NIO connections if soTimeout is 0.
setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setNodeMapper(NodeMapper<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Set a NodeMapper to use for generating the result object.
setNoReadErrorOnClose(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
setNotificationMapper(OutboundMessageMapper<Notification>) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Set a mapper for creating Notifications from a Message.
setNotificationPublisher(NotificationPublisher) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler.PublisherDelegate
 
setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Set header patterns ("xxx*", "*xxx", "*xxx*" or "xxx*yyy") that will NOT be copied from the inbound message if shouldCopyRequestHeaaders is true.
setNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Set headers that will NOT be copied from the inbound message if the handler is configured to copy headers.
setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
Set headers that will NOT be copied from the inbound message if the handler is configured to copy headers.
setNullResultHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setNullResultPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setObject(Object) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
setObjectName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the String value of the JMX MBean's ObjectName.
setObjectName(ObjectName...) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify the JMX ObjectNames (or patterns) of the notification publisher to which this notification listener should be subscribed.
setObjectName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify a default ObjectName to use when no such header is available on the Message being handled.
setObjectNameStaticProperties(Map<String, String>) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Static properties that will be added to all object names.
setOnFailureExpression(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the root message after a failed handler invocation.
setOnFailureExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the root message after a failed handler invocation.
setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
setOnSuccessExpression(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the message after a successful handler invocation.
setOnSuccessExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the message after a successful handler invocation.
setOperationName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify an operation name to be invoked when no such header is available on the Message being handled.
setOption(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify the array of options for various gateway commands.
setOptions(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify the options for various gateway commands as a space-delimited string.
setOptions(String) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
setOptions(ChangeStreamOptions) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setOrder(Integer) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the order in which the handler will be subscribed to its channel (when subscribable).
setOrder(int) - Method in interface org.springframework.integration.context.Orderable
Set the order for this component.
setOrder(int) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
setOrigin(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
setOrigin(String) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
setOutboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setOutboundHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide the header names that should be mapped to an HTTP request (for outbound adapters) or HTTP response (for inbound adapters) from a Spring Integration Message's headers.
setOutboundHeaderNames(String[]) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
 
setOutboundMessageMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setOutboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Specify a prefix to be appended to the JMS property name for any integration message header that is being mapped into the JMS Message.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the handler's output channel.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setOutputChannel(MessageChannel) - Method in interface org.springframework.integration.core.MessageProducer
Specify the MessageChannel to which produced Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the MessageChannel where Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setOutputChannelIfPresent(List<Annotation>, AbstractReplyProducingMessageHandler) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
setOutputChannelName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the handler's output channel name.
setOutputChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setOutputChannelName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setOutputChannelName(String) - Method in interface org.springframework.integration.core.MessageProducer
Specify the bean name of the MessageChannel to which produced Messages should be sent.
setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set the output channel name; overrides outputChannel if provided.
setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
setOutputChannelName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setOutputChannelName(String) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
setOutputChannelName(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setOutputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Specify a MessageGroupProcessor for the output function.
setOutputProperties(Properties) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
A set of output properties that will be used to override any of the same properties in affect for the transformation.
setOutputProperties(Properties) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
setOverride(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
Set the override trigger; set to null to revert to using the primary trigger.
setOverwrite(Boolean) - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
setOverwrite(Boolean) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
setPacketDeserializer(Deserializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
A Deserializer that will construct the full JSON content from the stream which is then passed to the JsonObjectMapper.
setPacketSerializer(Serializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
A Serializer that will delimit the full JSON content in the stream.
setParameterExpressions(Map<String, String>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Optionally maps parameter names to explicit expressions.
setParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
Define the (optional) parameter values.
setParameterSource(ParameterSource) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Specify the ParameterSource that would be used to provide additional parameters.
setParameterSourceFactory(ParameterSourceFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setParams(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setParser(RFC5424SyslogParser) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
setPartitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
setPassword(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setPassword(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The password to authenticate against the remote host.
setPassword(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setPath(String) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
setPathPatterns(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setPattern(String) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
setPattern(Pattern) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
setPatternMatch(boolean) - Method in class org.springframework.integration.transformer.HeaderFilter
 
setPatternResolver(ResourcePatternResolver) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setPatterns(String[]) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setPayload(Object) - Method in class org.springframework.integration.test.support.RequestResponseScenario
set the payload of the request message
setPayloadAsBytes(boolean) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
True if the converter should not convert the message payload to a String.
setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setPayloadExpression(Expression) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setPayloadExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setPayloadExpression(Expression) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specifies a SpEL expression to evaluate in order to generate the Message payload.
setPayloadExpression(Expression) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
Specify a SpEL expression to evaluate a payload against an incoming Message.
setPayloadExpressionString(String) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
When using a type-aware message converter (such as StringJsonMessageConverter, set the payload type the converter should create.
setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
When using a type-aware message converter (such as StringJsonMessageConverter, set the payload type the converter should create.
setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the payload type.
setPayloadType(Class<?>) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Set the type of the entityClass which is used for the EntityRowMapper.
setPayloadType(Class<?>) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
setPayloadType(JavaType) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
setPayloadType(Class<?>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
Set the type for target message payload to convert the WebSocket message body to.
setPermissions(File) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set permissions on newly written files.
setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
Set the persistence to pass into the client constructor.
setPersistMode(PersistMode) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setPhase(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setPhase(int) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setPhase(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
Set the phase.
setPhase(int) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setPhase(int) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setPhase(int) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setPhase(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
setPhase(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
setPhase(int) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
setPhase(int) - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
setPhase(int) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
setPipeTimeout(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setPollingDelay(long) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
The delay between checks of the file for new content in milliseconds.
setPoolSize(int) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Modify the target session pool size; the actual pool size will adjust up/down to this size as and when sessions are requested or retrieved.
setPoolSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
Set the pool size for deserialization buffers.
setPoolSize(int) - Method in class org.springframework.integration.util.SimplePool
Adjusts the current pool size.
setPoolWaitTimeout(long) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
Set the pool wait timeout if a pool is configured, default unlimited.
setPopSequence(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Perform a MessageBuilder.popSequenceDetails() for output message or not.
setPopSequence(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setPort(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setPort(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setPort(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Set the port; requires the factory to be stopped.
setPort(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setPort(int) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The port over which the SFTP connection shall be established.
setPort(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setPort(int) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
Sets the port on which the adapter listens; default is 514; note that the RFC does not specify a well known port for TCP; 514 is the well-known port for UDP.
setPort(int) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setPostProcessWithinAdvice(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
Specify whether the post processing should occur within the scope of any configured advice classes.
setPrefetchCount(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setPrefix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Specify the prefix to use for temporary files.
setPrefix(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Specify the prefix for target data base table used from queries.
setPrefix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify a prefix to be added to each channel name prior to resolution.
setPreparedStatementSetter(MessagePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
Specify a MessagePreparedStatementSetter to populate parameters on the PreparedStatement with the Message context.
setPreparedStatementSetter(ChannelMessageStorePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Set a ChannelMessageStorePreparedStatementSetter to insert message into the database.
setPreserveTimestamp(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setPreserveTimestamp(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set to true to preserve the destination file timestamp.
setPreserveTimestamp(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set to true to enable the preservation of the remote file timestamp when transferring.
setPreserveWireFeed(boolean) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
Specify a flag to indication if WireFeed should be preserved in the target SyndFeed.
setPreventDuplicates(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setPrimary(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
Set the primary trigger.
setPrimaryExpression(Expression) - Method in class org.springframework.integration.context.IntegrationObjectSupport
For expression-based components, set the primary expression.
setPriority(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPriority(Integer) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setPriority(boolean) - Method in class org.springframework.integration.store.MessageGroupQueue
If true, ensures that the message store supports priority.
setPriority(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setPriority(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setPriorityEnabled(boolean) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
setPriorityEnabled(boolean) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
setPrivateKey(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Allows you to set a Resource, which represents the location of the private key used for authenticating against the remote host.
setPrivateKeyPassphrase(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The password for the private key.
setProcedureParameters(List<ProcedureParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Custom Stored Procedure parameters that may contain static values or Strings representing an Expression.
setProcessorBean(Object) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setProducerRecordCreator(KafkaProducerMessageHandler.ProducerRecordCreator<K, V>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set a KafkaProducerMessageHandler.ProducerRecordCreator to create the ProducerRecord.
setProduces(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
 
setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
If set to 'false', this component will act as an Outbound Channel Adapter.
setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setPropagateEvaluationFailures(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true and an onSuccess expression evaluation fails with an exception, the exception will be thrown to the caller.
setPropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
setPropertiesPersister(PropertiesPersister) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the PropertiesPersister to use for parsing properties files.
setPropertyAccessors(Map<String, PropertyAccessor>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
Provide the map of expressions to evaluate when enriching the target payload.
setProt(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProtocol(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProtocol(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
The protocol used in SSLContext.getInstance(String); default "TLS".
setProtocol(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setProtocol(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setProtocols(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProxy(Proxy) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Allows for specifying a JSch-based Proxy.
setProxyDefaultMethods(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Indicate if default methods on the interface should be proxied as well.
setProxyExecutor(Executor) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Configure an executor to perform a ZeroMQ proxy loop.
setPublisherElementType(Class<?>) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Configure a type for a request Publisher elements.
setPublisherElementType(Class<?>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Configure a type for a request Publisher elements.
setPublisherElementTypeExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
Configure a SpEL expression to evaluate a request Publisher elements type at runtime against a request message.
setPublisherElementTypeExpression(Expression) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Configure a SpEL expression to evaluate a request Publisher elements type at runtime against a request message.
setPublishFailedEvents(boolean) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Enable or disable the publishing of failed events to the specified applicationEventPublisher.
setPublishPayload(boolean) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
Specify if payload should be published as is or the whole message must be wrapped to the MessagingEvent.
setPubSub(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPushbackBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
The size of the push back buffer; defaults to 1.
setPushbackCapable(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
Set to true to cause wrapping of the connection's input stream in a PushbackInputStream, enabling deserializers to "unread" data.
setQos(int...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
Set the QoS for each topic; a single value will apply to all topics otherwise the correct number of qos values must be provided.
setQosExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the qos expression; default "headers['mqtt_qos']".
setQosExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the qos expression; default "headers['mqtt_qos']".
setQueryExpression(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
setQueryExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setQueryExpressionReference(QueryExp) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
setQueryExpressionString(String) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
 
setQueryName(String) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
setQueryName(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
setQueryNameReference(ObjectName) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
setQueryType(R2dbcMessageHandler.Type) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Set a R2dbcMessageHandler.Type for query to execute.
setQueryTypeExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Set a SpEL expression to evaluate a R2dbcMessageHandler.Type for query to execute.
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.
setQueueSize(Integer) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setRawBytes(boolean) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
For messages with byte[] payloads, if rendered as JSON, Jackson performs Base64 conversion on the bytes.
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.
setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set to true to include the raw ConsumerRecord as headers with keys KafkaHeaders.RAW_DATA and IntegrationMessageHeaderAccessor.SOURCE_DATA.
setReactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
A registry of adapters to adapt a Reactive Streams Publisher to/from.
setReadDelay(long) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setReadDelay(long) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
The delay (in milliseconds) before retrying a read after the previous attempt failed due to insufficient threads.
setReadDelay(long) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setReadOffset(ReadOffset) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Define the offset from which we want to read message.
setReadOnlyHeaders(String...) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Specify a list of headers which should be considered as read only and prohibited from being populated in the message.
setReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
Specify a list of headers which should be considered as a read only and prohibited from the population to the message.
setReaperDelay(long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Set the reaper delay.
setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
setReceiveRaw(boolean) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Whether raw ZMsg is present as a payload of message to produce or it is fully converted to a Message including ZeroMqHeaders.TOPIC header (if any).
setReceiveTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setReceiveTimeout(long) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
setReceiveTimeout(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the max timeout value for the MessageConsumer's receive call when waiting for a reply.
setReceiveTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
This timeout (milliseconds) is used when retrieving elements from the queue specified by RedisQueueInboundGateway.boundListOperations.
setReceiveTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
This timeout (milliseconds) is used when retrieving elements from the queue specified by RedisQueueMessageDrivenEndpoint.boundListOperations.
setReceiveTimeout(int) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setRecipientMappings(Map<String, String>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the recipients for this router.
setRecipientMappings(Map<String, String>) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Set recipients.
setRecipients(List<RecipientListRouter.Recipient>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the recipients for this router.
setReconnectDelay(long) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
The time between connection attempts in milliseconds (default 10 seconds).
setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a RecordFilterStrategy to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into FilteringMessageListenerAdapter.
setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter to use with a record-based consumer.
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.
setRecoveryCallback(RecoveryCallback<Object>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted (unless an error channel is configured).
setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted (unless an error channel is configured).
setRecoveryInterval(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setRecoveryInterval(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setRecoveryInterval(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setRecoveryInterval(int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
The time (ms) to wait between reconnection attempts.
setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
setRecoveryInterval(int) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
Specify a reconnect interval in milliseconds in case of lost connection.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
setRefreshSharedInterval(long) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
When using a shared connection singleUse is false, specify how long to wait before trying to fail back to start from the beginning of the factory list.
setRegion(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
A unique grouping identifier for all locks persisted with this store.
setRegion(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
A unique grouping identifier for all messages persisted with this store.
setRegion(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
A unique grouping identifier for all messages persisted with this store.
setRegion(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
A unique grouping identifier for all messages persisted with this store.
setRegistryHost(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
setRegistryPort(int) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
setReleaseLockBeforeSend(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Set to true to release the message group lock before sending any output.
setReleaseLockBeforeSend(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Set releasePartialSequences on an underlying default SequenceSizeReleaseStrategy.
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
Flag that determines if partial sequences are allowed.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the ReleaseStrategy that should be used when deciding if a group in this barrier may be released.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setReliabilityAttributes(boolean, boolean, String, int, int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Specify the full path to the remote directory.
setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Specify the full path to the remote directory.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Specify an expression that evaluates to the full path to the remote directory.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the remote directory expression used to determine the remote directory to which files will be sent.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Specify a remote directory path SpEL expression.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the remote directory expression used to determine the remote directory to which files will be sent.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Specify an expression that evaluates to the full path to the remote directory.
setRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Specify a remote directory path SpEL expression.
setRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Specify an expression that evaluates to the full path to the remote directory.
setRemoteFileMetadataStore(MetadataStore) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Configure a MetadataStore to hold a remote file info (host, port, remote directory) to transfer downstream in message headers when local file is pulled.
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
Set the remote file separator; default '/'
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the file separator when dealing with remote files; default '/'.
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Specify a remote file separator symbol.
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the file separator when dealing with remote files; default '/'.
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
setRemoteTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setRemoteTimeoutExpression(Expression) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setRemoveBatchSize(int) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
Set the batch size when bulk removing messages from groups for message stores that support batch removal.
setRemoveMessage(boolean) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
setRemoveOnGet(boolean) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Set to true to immediately remove the channel mapping when DefaultHeaderChannelRegistry.channelNameToChannel(String) is invoked.
setRenameExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression for files renaming during transfer.
setRenameExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Specify a SpEL expression for files renaming during transfer.
setReopen(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setReopen(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
If true, close and reopen the file between reading chunks; default false.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
Deprecated.
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Sets the content enricher's reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel name.
setReplyChannelName(String) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Specify the Spring Integration reply channel name.
setReplyChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setReplyChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setReplyChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setReplyChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setReplyContainerProperties(JmsOutboundGateway.ReplyContainerProperties) - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
setReplyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the delivery mode for JMS reply Messages.
setReplyDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination from which reply Messages should be received.
setReplyDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the SpEL Expression to be used for determining the reply Destination instance or reply destination name.
setReplyDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination from which reply Messages should be received.
setReplyHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Provide the header names that should be mapped to a response from a MessageHeaders.
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.
setReplyKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Specify the key to be used when adding the reply Message or payload to the core map (will be payload only unless the value of BaseHttpInboundEndpoint.setExtractReplyPayload(boolean) is false).
setReplyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an OutboundMessageMapper for mapping to objects from any reply Messages received in receive or sendAndReceive operations.
setReplyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set a message converter for gateway replies.
setReplyPayloadToFlux(boolean) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
The boolean flag to identify if the reply payload should be as a Flux from the response body or as resolved value from the Mono of the response body.
setReplyPayloadType(Type) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
When using a type-aware message converter (such as StringJsonMessageConverter, set the payload type the converter should create.
setReplyPriority(int) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the priority value for JMS reply Messages.
setReplyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether the reply destination is a Topic.
setReplySqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setReplyTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for receiving reply messages.
setReplyTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setReplyTimeout(long) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setReplyTimeout(long) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
Specifies the time the gateway will wait to send the result to the reply channel.
setReplyTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the timeout value for receiving reply messages.
setReplyTimeToLive(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the time-to-live property for JMS reply Messages.
setRequestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the request channel.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
Specify the request channel where messages will be sent.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Sets the content enricher's request channel.
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the request channel name.
setRequestChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setRequestChannelName(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Deprecated.
 
setRequestChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setRequestDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination to which request Messages should be sent.
setRequestDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the SpEL Expression to be used for determining the request Destination instance or request destination name.
setRequestDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination to which request Messages should be sent.
setRequestedContentTypeResolver(RequestedContentTypeResolver) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
A strategy to resolve the requested media types for a ServerWebExchange.
setRequestElementClass(Class<?>) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Specify a type of payload to be generated when the inbound RSocket request content is read by the encoders.
setRequestElementType(ResolvableType) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Specify the type of payload to be generated when the inbound RSocket request content is read by the converters/encoders.
setRequestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the ClientHttpRequestFactory for the underlying RestTemplate.
setRequestHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Provide the header names that should be mapped from a request to a MessageHeaders.
setRequestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an InboundMessageMapper for creating request Messages from any object passed in a send or sendAndReceive operation.
setRequestMapping(RequestMapping) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Set the RequestMapping which allows you to specify a flexible RESTFul-mapping for this endpoint.
setRequestPayloadExpression(Expression) - Method in class org.springframework.integration.transformer.ContentEnricher
By default the original message's payload will be used as the actual payload that will be send to the request-channel.
setRequestPayloadType(ResolvableType) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify the type of payload to be generated when the inbound HTTP request content is read by the converters/encoders.
setRequestPayloadTypeClass(Class<?>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify the type of payload to be generated when the inbound HTTP request content is read by the converters/encoders.
setRequestPreparedStatementSetter(MessagePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setRequestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether the request destination is a Topic.
setRequestSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setRequestTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for sending request messages.
setRequestTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setRequestTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestTimeout(long) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setRequestTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the timeout value for sending request messages.
setRequiresReply(Boolean) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Flag whether a reply is required.
setRequiresReply(boolean) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
 
setRequiresReply(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
setRequiresReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify whether this router should ignore any failure to resolve a channel name to an actual MessageChannel instance when delegating to the ChannelResolver strategy.
setResource(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the ResourceLoader to use for loading bundle properties files.
setResponseValidator(AbstractResponseValidator<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
Set the response validator
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Sets the ResultFactory.
setResultFactoryName(String) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
setResultFactoryName(String) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setResultType(String) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
setResultType(String) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setRetainedExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the retained expression; default "headers['mqtt_retained']".
setRetainedExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the retained expression; default "headers['mqtt_retained']".
setRetryDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
Set an additional delay to apply when retrying after a release failure.
setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
Configure a retry interval.
setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
setRetryStateGenerator(RetryStateGenerator) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
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.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
Set the retry template.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Specify a RetryTemplate instance to wrap KafkaInboundGateway.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
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
 
setReturnFailureExpressionResult(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true, the result of evaluating the onFailureExpression will be returned as the result of AbstractReplyProducingMessageHandler.handleRequestMessage(Message).
setReturningResultSetRowMappers(Map<String, RowMapper<?>>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
If the Stored Procedure returns ResultSets you may provide a map of RowMapper to convert the ResultSet to meaningful objects.
setReturnValueRequired(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Indicates the procedure's return value should be included in the results returned.
setRightPop(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
Specify if POP operation from Redis List should be BRPOP or BLPOP.
setRole(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setRole(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setRole(String) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
Specify the role for the endpoint.
setRole(String) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
Configure a role for DefaultCandidate.
setRolledBack(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
setRolledBack(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
setRoot(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
Root node - store entries are children of this node.
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
 
setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setRSocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Provide an AbstractRSocketConnector reference for an explicit endpoint mapping.
setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
Configure a RSocketStrategies for data encoding/decoding.
setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Configure an RSocketStrategies instead of a default one.
setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
 
setScanEachPoll(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanEachPoll(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optionally specify a custom scanner, for example the WatchServiceDirectoryScanner
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Switch the local FileReadingMessageSource to use a custom DirectoryScanner.
setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.ImapMailReceiver
Provides a way to set custom SearchTermStrategy to compile a SearchTerm to be applied when retrieving mail
setSecondChanceDelay(int) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
When using NIO and the server closes the socket after sending the reply, an error message representing the close may appear before the reply.
setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
Initialize the selector chain.
setSelectQuery(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Set the select query.
setSelectSqlParameterSource(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
A source of parameters for the select query used for polling.
setSendBufferSizeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the failure channel.
setSendFailureChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the failure channel name.
setSendingTaskExecutor(Executor) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
Specify an Executor used to send messages received by the adapter.
setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setSendPartialResultOnExpiry(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setSendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
The Consumer callback to configure a publishing socket.
setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the success channel.
setSendSuccessChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the Success channel name.
setSendTimeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Configure the default timeout value to use for send operations.
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the maximum time to wait for a Message to be sent to the output channel.
setSendTimeout(Long) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Set the timeout for sending reply Messages.
setSendTimeout(long) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setSendTimeout(long) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Specify a timeout in milliseconds for how long this KafkaProducerMessageHandler should wait wait for send operation results.
setSendTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the timeout for sending a message to the resolved channel.
setSendTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setSendTimeout(long) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setSendTimeoutExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Specify a SpEL expression to evaluate a timeout in milliseconds for how long this KafkaProducerMessageHandler should wait wait for send operation results.
setSequence(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setSequenceNumber(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setSequenceNumber(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSerializationContext(RedisSerializationContext<String, ?>) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
A converter for serializing messages to byte arrays for storage.
setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
A converter for serializing messages to byte arrays for storage.
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
setSerializer(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Provide the MBeanServer where the JMX MBean has been registered.
setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
Provide the MBeanServer where the JMX MBean has been registered.
setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Provide a reference to the MBeanServer where the notification publishing MBeans are registered.
setServerAliveCountMax(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Specifies the number of server-alive messages, which will be sent without any reply from the server before disconnecting.
setServerAliveInterval(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Sets the timeout interval (milliseconds) before a server alive message is sent, in case no message is received from the server.
setServerConfigurer(Consumer<RSocketServer>) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Provide a Consumer to configure the RSocketServer.
setServiceName(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setSession(Session) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Set the Session.
setSession(Session) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSessionAcknowledgeMode(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setSessionAcknowledgeMode(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
Set the session acknowledge mode on the listener container.
setSessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setSessionAcknowledgeModeName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setSessionConfig(Properties) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Using Properties, you can set additional configuration settings on the underlying JSch Session.
setSessionCookieNeeded(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setSessionCreation(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setSessionTransacted(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSessionTransacted(Boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setSessionWaitTimeout(long) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Sets the limit of how long to wait for a session to become available.
setSetupData(Object) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Set the data for the setup payload.
setSetupMetadata(Map<Object, MimeType>) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Add metadata to the setup payload.
setSetupRoute(String) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Set the route for the setup payload.
setSetupRouteVariables(Object...) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Set the variables for route template to expand with.
setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
setShouldClonePayload(boolean) - Method in class org.springframework.integration.transformer.ContentEnricher
Specify whether to clone payload objects to create the target object.
setShouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Specify whether mail messages should be deleted after retrieval.
setShouldDeleteMessages(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setShouldExtractPayload(boolean) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
setShouldFlattenKeys(boolean) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
Specify whether to log the full Message.
setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.ImapMailReceiver
Specify if messages should be marked as read.
setShouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
Specify whether the IDLE task should reconnect automatically after catching a FolderClosedException while waiting for messages.
setShouldSkipNulls(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
Specify whether null values, such as might be returned from an expression evaluation, should be skipped.
setShouldTrack(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify whether this component should be tracked in the Message History.
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Specify whether this gateway should be tracked in the Message History of Messages that originate from its send or sendAndReceive operations.
setShouldTrack(boolean) - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
setShouldTrack(boolean) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setShouldTrack(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setShouldTrack(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
 
setShouldTrack(boolean) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
setShouldTrack(boolean) - Method in interface org.springframework.integration.support.management.TrackableComponent
 
setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setShouldUnbindAtCompletion(boolean) - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
Specify if the IntegrationResourceHolderSynchronization.resourceHolder should be unbound from the Thread Local store at transaction completion or not.
setShutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
Set to false to prevent listener container shutdown when the endpoint is stopped.
setShutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
Set to false to prevent listener container shutdown when the endpoint is stopped.
setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setSimpleContent(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
MimeMessage.getContent() returns just the email body.
setSimpleContent(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSingleUse(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
If true, sockets created by this factory will be used once.
setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
Ignored on this factory; connections are always cached in the pool.
setSkipUndeclaredResults(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
If this variable is set to true then all results from a stored procedure call that don't have a corresponding SqlOutParameter declaration will be bypassed.
setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Sets socket attributes on the socket.
setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Sets timeout and receive buffer size; calls the socket customizer.
setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Provide a Consumer to configure a socket with arbitrary options, like security.
setSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Provide a Consumer to configure a socket with arbitrary options, like security.
setSocketCustomizer(SocketCustomizer) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Set a customizer to further configure the socket after creation.
setSocketCustomizer(SocketCustomizer) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Set a customizer to further configure the socket after creation.
setSocketExpression(Expression) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketExpressionString(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketFactory(SocketFactory) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Allows you to pass in a SocketFactory.
setSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSockJsServiceOptions(ServerWebSocketContainer.SockJsServiceOptions) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoLinger(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoReceiveBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoSendBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoTimeout(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSource(Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Set the configuration source Object for this manual Integration flow definition.
setSource(Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the source to be polled for Messages.
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
Provide the SourceFactory to be used.
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Sets the SourceFactory.
setSqlParameters(List<SqlParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
If you database system is not fully supported by Spring and thus obtaining parameter definitions from the JDBC Meta-data is not possible, you must define the SqlParameter explicitly.
setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Provides the ability to set a custom SqlParameterSourceFactory.
setSqlParameterTypes(Map<String, Integer>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Specify sql types for the parameters.
setSslContextSupport(TcpSSLContextSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSslHandshakeTimeout(Integer) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
Set the SSL handshake timeout (only used with SSL and NIO).
setSslHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Set the handshake timeout used when waiting for SSL handshake data; only applies to SSL connections, when using NIO.
setSslHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setStanzaFilter(StanzaFilter) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
Specify a StanzaFilter to use for the incoming packets.
setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters can be added (default is empty).
setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Define some static parameter values.
setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters can be added (default is empty).
setStatusCodeExpression(Expression) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify the Expression to resolve a status code for Response to override the default '200 OK' or '500 Internal Server Error' for a timeout.
setStatusCodeExpressionString(String) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify the Expression to resolve a status code for Response to override the default '200 OK' or '500 Internal Server Error' for a timeout.
setStatusCodeIfNeeded(ServerHttpResponse, HttpEntity<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
setStoredProcedureName(String) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
The name of the Stored Procedure or Stored Function to be executed.
setStoredProcedureNameExpression(Expression) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Using the StoredProcExecutor.storedProcedureNameExpression the Message can be used as source for the name of the Stored Procedure or Stored Function.
setStoreUri(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setStreamBytesLimit(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setStreamReceiverOptions(StreamReceiver.StreamReceiverOptions<String, ?>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
Set ReactiveStreamOperations used to customize the StreamReceiver.
setStringToBytes(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Sets whether outbound String payloads are to be converted to byte[].
setSubscribeSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
The Consumer callback to configure a consuming socket.
setSubscriptionDurable(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSubscriptionMode(Roster.SubscriptionMode) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
Sets the subscription processing mode, which dictates what action Smack will take when subscription requests from other users are made.
setSubscriptionShared(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSuccessChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel to which to send the AdviceMessage after evaluating the success expression.
setSuccessChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel name to which to send the AdviceMessage after evaluating the success expression.
setSuffix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Specify the suffix to use for temporary files.
setSuffix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify a suffix to be added to each channel name prior to resolution.
setSupportedEventTypes(EventType...) - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
 
setSupportedEventTypes(CqEventType...) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
setSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
setSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
setSuppressCors(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
A boolean indicating if the KafkaProducerMessageHandler should wait for the send operation results or not.
setSyndFeedInput(SyndFeedInput) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
Specify a parser for Feed XML documents.
setTableName(String) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Specify a table in the target database to execute the query.
setTableNameExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Set a SpEL expression to evaluate a table name at runtime against request message.
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
Public setter for the table prefix property.
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Public setter for the table prefix property.
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
Public setter for the table prefix property.
setTailAttemptsDelay(long) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
The delay in milliseconds between attempts to tail a non-existent file, or between attempts to execute a process if it fails for any reason.
setTarget(Object) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
setTarget(Object) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
setTargetMethodName(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set the method name for the message handler.
setTargetObject(Object) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set the target POJO for the message handler.
setTaskExecutor(Executor) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
A task executor; default is a SimpleAsyncTaskExecutor.
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
Specify an Executor used for running the message listeners when messages are received.
setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Configure a TaskScheduler for those components which logic relies on the scheduled tasks.
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
Set the TcpNetConnectionSupport to use to create connection objects.
setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
Set the TcpNetConnectionSupport to use to create connection objects.
setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
setTcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setTcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
setTemplateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
By default, every file that is in the process of being transferred will appear in the file system with an additional suffix, which by default is ".writing".
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set the temporary suffix to use when transferring files to the remote system.
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Set the temporary suffix to use when transferring files to the remote system.
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set the temporary suffix to use when transferring files to the remote system.
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Set a temporary file suffix to be used while transferring files.
setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set a temporary remote directory expression; used when transferring files to the remote system.
setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Specify a remote directory path SpEL expression.
setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set a temporary remote directory expression; used when transferring files to the remote system.
setTemporaryRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
Specify a remote directory path SpEL expression.
setTestSession(boolean) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
Set to true to test the session when checking one out from the cache.
setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
Sets the underlying connection (or next interceptor)
setThreadKey(Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Set a key to be used for DelegatingSessionFactory.getSession() on this thread.
setThreadKey(Message<?>, Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Messaging-friendly version of DelegatingSessionFactory.setThreadKey(Object) that can be invoked from a service activator.
setThreshold(int) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
setThrowExceptionOnLateReply(boolean) - Method in class org.springframework.integration.core.MessagingTemplate
 
setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.filter.MessageFilter
Specify whether this filter should throw a MessageRejectedException when its selector does not accept a Message.
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify whether this interceptor should throw a MessageRejectedException when its selector does not accept a Message.
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
setTimeout(long) - Method in class org.springframework.integration.channel.interceptor.WireTap
Specify the timeout value for sending to the intercepting target.
setTimeout(long) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify the timeout value for sending to the discard channel.
setTimeout(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The timeout property is used as the socket timeout parameter, as well as the default connection timeout.
setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Timeout in milliseconds (default -1).
setTimeoutBuffer(int) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set a buffer, in milliseconds, added to the configured delivery.timeout.ms to determine the minimum time to wait for the send future completion when sync is true.
setTimeoutDuration(Duration) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Change the timeoutDuration option of the RateLimiterRequestHandlerAdvice.rateLimiter.
setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Allows you to override the rule for the timeout calculation.
setTimestamp(long) - Method in class org.springframework.integration.store.MessageHolder
 
setTimestamp(long) - Method in class org.springframework.integration.store.MessageMetadata
 
setTimestampExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Specify a SpEL expression to evaluate a timestamp that will be added in the Kafka record.
setTimeToLive(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Set the underlying MulticastSocket time to live property.
setTimeToLive(int) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Specify the time (in milliseconds) to expire dead locks.
setTimeToLive(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the timeToLive for each sent Message.
setTimeToLiveExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify a SpEL expression to evaluate a timeToLive for the JMS message to send.
setTimeToLiveExpressionString(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify a SpEL expression to evaluate a timeToLive for the JMS message to send.
setTopic(String) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setTopic(String) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Specify a topic the SocketType.PUB socket is going to use for distributing messages into the subscriptions.
setTopicExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
setTopicExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the topic expression; default "headers['mqtt_topic']".
setTopicExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setTopicExpression(Expression) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Specify a SpEL expression to evaluate a topic a SocketType.PUB is going to use for distributing messages into the subscriptions.It is ignored for all other SocketTypes supported.
setTopicExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Set the topic expression; default "headers['mqtt_topic']".
setTopicPatterns(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setTopics(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Specify topics the SocketType.SUB socket is going to use for subscription.
setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
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
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransactionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTransactionTimeout(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransferCookies(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set to true if you wish 'Set-Cookie' headers in responses to be transferred as 'Cookie' headers in subsequent interactions for a message.
setTransportHandlers(TransportHandler...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setTrapException(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true, any exception will be caught and null returned.
setTrigger(Trigger) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTrigger(Trigger) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTrustedSpel(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set to true if you trust the source of SpEL expressions used to evaluate URI variables.
setTrustManager(TrustManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setTrustStoreType(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
Set the trust store type.
setType(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setTypeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
Set the expression to evaluate against the message to determine the type.
setTypeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
Set the expression to evaluate against the message to determine the value for the AvroHeaders.TYPE header.
setTypeExpressionString(String) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
Set the expression to evaluate against the message to determine the type id.
setTypeExpressionString(String) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
Set the expression to evaluate against the message to determine the value for the AvroHeaders.TYPE header.
setTypeLocator(TypeLocator) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
setUnmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setUnsolicitedMessageChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Set the channel for unsolicited incoming messages, or late replies.
setUnsolicitedMessageChannelName(String) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Set the channel name for unsolicited incoming messages, or late replies.
setUp() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
 
setupCustomPostProcessors() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setUpdatePerRow(boolean) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUpdateSql(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
Set an update query that will be passed to the DatabaseClient.sql(String) method.
setUpdateSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setupDefaultInboundMapper(DefaultHttpHeaderMapper) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Subclasses can call this from a static inboundMapper() method to set up standard header mappings for an inbound mapper.
setupDefaultOutboundMapper(DefaultHttpHeaderMapper) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Subclasses can call this from a static outboundMapper() method to set up standard header mappings for an outbound mapper.
setupResponseAndConvertReply(ServletServerHttpResponse, Message<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Converts the reply message to the appropriate HTTP reply object and sets up the ServletServerHttpResponse.
setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
setUriVariablesExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
Set the Expression to evaluate against the outbound message; the expression must evaluate to a Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
setUseBroker(boolean) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
Specify if this adapter should use an existing single AbstractBrokerMessageHandler bean for non-MESSAGE WebSocketMessages and to route messages with broker destinations.
setUseClientMode(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setUsePayloadAsParameterSource(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
If set to 'true', the payload of the Message will be used as a source for providing parameters.
setUsePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
setUser(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
The remote user to use.
setUser(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setUserDefinedHeaderPrefix(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Sets the prefix to use with user-defined (non-standard) headers.
setUseReplyContainer(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
setUserFlag(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default "spring-integration-mail-adapter".
setUserFlag(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setUserInfo(UserInfo) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
Provide a UserInfo which exposes control over dealing with new keys or key changes.
setUsername(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setUseSpelInvoker(boolean) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
A boolean flag to use SpEL Expression evaluation or InvocableHandlerMethod for target method invocation.
setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
A boolean flag to use SpEL Expression evaluation or InvocableHandlerMethod for target method invocation.
setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
A boolean flag to use SpEL Expression evaluation or InvocableHandlerMethod for target method invocation.
setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Set whether a temporary file name is used when sending files to the remote system.
setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
A boolean flag to use temporary files names or not.
setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Set whether a temporary file name is used when sending files to the remote system.
setUseWatchService(boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setUseWatchService(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Switch this FileReadingMessageSource to use its internal FileReadingMessageSource.WatchServiceDirectoryScanner.
setUseWatchService(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Switch the local FileReadingMessageSource to use its internal FileReadingMessageSource.WatchServiceDirectoryScanner.
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
When set to true, connections created by this factory attempt to use direct buffers where possible.
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
If true, connection will attempt to use direct buffers where possible.
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
setUsingIdCache(boolean) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Consider using this property when polling the database transactionally using multiple parallel threads, meaning when the configured poller is configured using a task executor.
setUsingNio(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setUuidRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for UUID.
setValidator(Validator) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
Specify a Validator to validate a converted payload from request.
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValue(Object) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
setValue(Object) - Method in class org.springframework.integration.jpa.support.JpaParameter
 
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValues(PreparedStatement, Message<?>) - Method in interface org.springframework.integration.jdbc.MessagePreparedStatementSetter
 
setValues(PreparedStatement, Message<?>, Object, String, boolean) - Method in class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
Perform a preparedStatement parameters population according provided arguments.
setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
Use a different serializer (default JdkSerializationRedisSerializer for the Message.
setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.store.RedisMessageStore
 
setValuesExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
Set a SpEL expression to evaluate a Map for name-value pairs to bind as parameters into a query.
setValueTypeExpression(Expression) - Method in class org.springframework.integration.json.JsonToObjectTransformer
Configure a SpEL Expression to evaluate a ResolvableType to instantiate the payload from the incoming JSON.
setValueTypeExpressionString(String) - Method in class org.springframework.integration.json.JsonToObjectTransformer
Configure a SpEL expression to evaluate a ResolvableType to instantiate the payload from the incoming JSON.
setViewExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Specifies a SpEL expression to evaluate in order to generate the view name.
setViewName(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Specify the view name.
setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
Specify the voting strategy for this selector chain.
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.
setWaitTimeout(long) - Method in class org.springframework.integration.util.SimplePool
Adjusts the wait timeout - the time for which getItem() will wait if no idle entries are available.
setWantsClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setWatchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setWatchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.file.FileReadingMessageSource
The WatchService event types.
setWebServiceTemplate(WebServiceTemplate) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setWebSocketEnabled(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setWindowConfigurer(Function<Flux<Message<?>>, Flux<Flux<Message<?>>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Configure a Function to apply a transformation into the grouping Flux for any arbitrary Flux.window(int) options not covered by the simple options.
setWindowSize(int) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Specify a size for windows to close.
setWindowSizeFunction(Function<Message<?>, Integer>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Specify a Function to determine a size for windows to close against the first message in group.
setWindowTimespan(Duration) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
Configure a Duration for closing windows periodically.
setWorkingDirExpression(Expression) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Specify an Expression to evaluate FTP client working directory against request message.
setWorkingDirExpressionString(String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
Specify a SpEL Expression to evaluate FTP client working directory against request message.
setXmlPayloadConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setXslParameterMappings(Map<String, Expression>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setXsltParamHeaders(String...) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setZeroMqProxy(ZeroMqProxy) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
Specify a reference to a ZeroMqProxy instance in the same application to rely on its ports configuration and make a natural lifecycle dependency without guessing when the proxy is started.
setZsetIncrementExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Set the expression used as the INCR flag for the ZADD command in case of ZSet collection.
setZsetIncrementExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
Set the expression used as the INCR flag for the ZADD command in case of ZSet collection.
SEVERITY - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
SEVERITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
SEVERITY_TEXT - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
Sftp - Class in org.springframework.integration.sftp.dsl
The factory for SFTP components.
SftpFileInfo - Class in org.springframework.integration.sftp.session
A FileInfo implementation for SFTP.
SftpFileInfo(ChannelSftp.LsEntry) - Constructor for class org.springframework.integration.sftp.session.SftpFileInfo
 
SftpInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
Parser for 'sftp:inbound-channel-adapter'
SftpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
SftpInboundChannelAdapterSpec - Class in org.springframework.integration.sftp.dsl
SftpInboundChannelAdapterSpec(SessionFactory<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
 
SftpInboundFileSynchronizer - Class in org.springframework.integration.sftp.inbound
Handles the synchronization between a remote SFTP directory and a local mount.
SftpInboundFileSynchronizer(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
Create a synchronizer with the SessionFactory used to acquire Session instances.
SftpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.sftp.inbound
A MessageSource implementation for SFTP that delegates to an InboundFileSynchronizer.
SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
SftpMessageHandler - Class in org.springframework.integration.sftp.outbound
Subclass of FileTransferringMessageHandler for SFTP.
SftpMessageHandler(SftpRemoteFileTemplate) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
 
SftpMessageHandler(SftpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
 
SftpMessageHandler(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
 
SftpMessageHandlerSpec - Class in org.springframework.integration.sftp.dsl
 
SftpMessageHandlerSpec(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
 
SftpMessageHandlerSpec(RemoteFileTemplate<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
Deprecated.
SftpMessageHandlerSpec(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
Deprecated.
SftpMessageHandlerSpec(SftpRemoteFileTemplate) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
 
SftpMessageHandlerSpec(SftpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
 
SftpNamespaceHandler - Class in org.springframework.integration.sftp.config
Provides namespace support for using SFTP.
SftpNamespaceHandler() - Constructor for class org.springframework.integration.sftp.config.SftpNamespaceHandler
 
SftpOutboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
Parser for SFTP Outbound Channel Adapters.
SftpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
 
SftpOutboundGateway - Class in org.springframework.integration.sftp.gateway
Outbound Gateway for performing remote file operations via SFTP.
SftpOutboundGateway(SessionFactory<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
Construct an instance using the provided session factory and callback for performing operations on the session.
SftpOutboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
Construct an instance with the supplied remote file template and callback for performing operations on the session.
SftpOutboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
SftpOutboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, String, String) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
SftpOutboundGatewayParser - Class in org.springframework.integration.sftp.config
 
SftpOutboundGatewayParser() - Constructor for class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
SftpOutboundGatewaySpec - Class in org.springframework.integration.sftp.dsl
 
SftpOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
 
SftpPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.sftp.filters
Persistent file list filter using the server's file timestamp to detect if we've already 'seen' this file.
SftpPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
 
SftpRegexPatternFileListFilter - Class in org.springframework.integration.sftp.filters
Implementation of AbstractRegexPatternFileListFilter for SFTP.
SftpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
SftpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
SftpRemoteFileTemplate - Class in org.springframework.integration.sftp.session
SFTP version of RemoteFileTemplate providing type-safe access to the underlying ChannelSftp object.
SftpRemoteFileTemplate(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
 
SftpSession - Class in org.springframework.integration.sftp.session
Default SFTP Session implementation.
SftpSession(Session) - Constructor for class org.springframework.integration.sftp.session.SftpSession
 
SftpSession(JSchSessionWrapper) - Constructor for class org.springframework.integration.sftp.session.SftpSession
 
SftpSimplePatternFileListFilter - Class in org.springframework.integration.sftp.filters
Implementation of AbstractSimplePatternFileListFilter for SFTP.
SftpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
 
SftpStreamingInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
 
SftpStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
SftpStreamingInboundChannelAdapterSpec - Class in org.springframework.integration.sftp.dsl
 
SftpStreamingInboundChannelAdapterSpec(RemoteFileTemplate<ChannelSftp.LsEntry>, Comparator<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
 
SftpStreamingMessageSource - Class in org.springframework.integration.sftp.inbound
Message source for streaming SFTP remote file contents.
SftpStreamingMessageSource(RemoteFileTemplate<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
Construct an instance with the supplied template.
SftpStreamingMessageSource(RemoteFileTemplate<ChannelSftp.LsEntry>, Comparator<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
Construct an instance with the supplied template and comparator.
SftpSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.sftp.filters
SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>, String) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>, Function<String, String>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
SftpSystemMarkerFilePresentFileListFilter(Map<FileListFilter<ChannelSftp.LsEntry>, Function<String, String>>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
SharedSessionCapable - Interface in org.springframework.integration.file.remote.session
A SessionFactory that implements this interface is capable of supporting a shared session.
shouldClonePayload(boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.filter.MessageFilter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Subclasses may override this.
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.BridgeHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.DelayHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
Determine if the provided method and its annotations are eligible to create an AbstractEndpoint.
shouldDeleteMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Indicates whether the mail messages should be deleted after being received.
shouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
shouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
A flag to specify if messages should be deleted after receive.
shouldFireEvents() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
shouldFireEvents() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
shouldFireEvents() - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
shouldFlush(String, long, long) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.FlushPredicate
Return true to cause the file to be flushed and closed.
shouldFlush(String, long, long, Message<?>) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.MessageFlushPredicate
Return true to cause the file to be flushed and closed.
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateId() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.zookeeper.config.xml.LeaderListenerParser
 
shouldIntercept(String, InterceptableChannel) - Method in interface org.springframework.integration.channel.interceptor.VetoCapableInterceptor
 
shouldIntercept(String, InterceptableChannel) - Method in class org.springframework.integration.channel.interceptor.WireTap
 
shouldMapInboundHeader(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
A flag to determine if message should be marked as read.
shouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
shouldSkipNulls(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
 
shouldSplitOutput(Iterable<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
shouldTrack(boolean) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Whether component should be tracked or not by message history.
shouldTrack(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
Whether component should be tracked or not by message history.
shouldTrack() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
shouldUnbindAtCompletion() - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
shutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
Set to false to prevent listener container shutdown when the endpoint is stopped.
shutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
Set to false to prevent listener container shutdown when the endpoint is stopped.
shutdownInput() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Set the connection's input stream to end of stream.
shutdownInput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Set the socket's input stream to end of stream.
shutdownInput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Set the socket's input stream to end of stream.
shutdownOutput() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Disable the socket's output stream.
shutdownOutput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Disable the socket's output stream.
shutdownOutput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Disable the socket's output stream.
shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the timeout for shutting down the container.
SIMPLE_CALLBACK - Static variable in class org.springframework.integration.expression.ExpressionEvalMap
 
SimpleAcknowledgment - Interface in org.springframework.integration.acks
Opaque object for manually acknowledging.
SimpleActiveIdleMessageSourceAdvice - Class in org.springframework.integration.aop
Deprecated.
since 5.3 in favor of SimpleActiveIdleReceiveMessageAdvice with the same (but more common) functionality.
SimpleActiveIdleMessageSourceAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Deprecated.
 
SimpleActiveIdleReceiveMessageAdvice - Class in org.springframework.integration.aop
A simple advice that polls at one rate when messages exist and another when there are no messages.
SimpleActiveIdleReceiveMessageAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
 
simpleContent(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Determine how the content is rendered.
SimpleFromAvroTransformer - Class in org.springframework.integration.transformer
An Apache Avro transformer to create generated SpecificRecord objects from byte[].
SimpleFromAvroTransformer(Class<? extends SpecificRecord>) - Constructor for class org.springframework.integration.transformer.SimpleFromAvroTransformer
Construct an instance with the supplied default type to create.
simpleInboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance.
SimpleIncrementingIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
SimpleJsonSerializer - Class in org.springframework.integration.json
Extremely simple JSON serializer.
SimpleMessageConverter - Class in org.springframework.integration.support.converter
 
SimpleMessageConverter() - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageGroup - Class in org.springframework.integration.store
Represents a mutable group of correlated messages that is bound to a certain MessageStore and group id.
SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object, long, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<Message<?>>, Collection<? extends Message<?>>, Object, long, boolean, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroupFactory - Class in org.springframework.integration.store
The MessageGroupFactory implementation to produce SimpleMessageGroup instances.
SimpleMessageGroupFactory() - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
 
SimpleMessageGroupFactory(SimpleMessageGroupFactory.GroupType) - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
 
SimpleMessageGroupFactory.GroupType - Enum in org.springframework.integration.store
 
SimpleMessageGroupProcessor - Class in org.springframework.integration.aggregator
A MessageGroupProcessor that simply returns the messages in the group.
SimpleMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.SimpleMessageGroupProcessor
 
SimpleMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
SimpleMessageListenerContainerSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
SimpleMessageStore - Class in org.springframework.integration.store
Map-based in-memory implementation of MessageStore and MessageGroupStore.
SimpleMessageStore(int, int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity, or unlimited size if the given capacity is less than 1.
SimpleMessageStore(int, int, long) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity and the timeout in millisecond to wait for the empty slot in the store.
SimpleMessageStore(int, int, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity and LockRegistry for the message group operations concurrency.
SimpleMessageStore(int, int, long, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity, the timeout in millisecond to wait for the empty slot in the store and LockRegistry for the message group operations concurrency.
SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with unlimited capacity
SimpleMetadataStore - Class in org.springframework.integration.metadata
Simple implementation of MetadataStore that uses a ConcurrentMap for the data store.
SimpleMetadataStore() - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
Instantiate a SimpleMetadataStore using an in-memory ConcurrentHashMap.
SimpleMetadataStore(ConcurrentMap<String, String>) - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
Instantiate a SimpleMetadataStore using the provided ConcurrentMap.
SimpleMultipartFileReader - Class in org.springframework.integration.http.multipart
MultipartFileReader implementation that does not maintain metadata from the original MultipartFile instance.
SimpleMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.SimpleMultipartFileReader
 
simpleOutboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance.
simpleOutboundGateway(WebServiceTemplate) - Static method in class org.springframework.integration.ws.dsl.Ws
Create an instance with the provided WebServiceTemplate.
SimplePatternFileListFilter - Class in org.springframework.integration.file.filters
Filter that supports ant style path expressions, which are less powerful but more readable than regular expressions.
SimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.SimplePatternFileListFilter
 
SimplePollSkipStrategy - Class in org.springframework.integration.scheduling
A simple PollSkipStrategy to be used with a PollSkipAdvice.
SimplePollSkipStrategy() - Constructor for class org.springframework.integration.scheduling.SimplePollSkipStrategy
 
SimplePool<T> - Class in org.springframework.integration.util
Implementation of Pool supporting dynamic resizing and a variable timeout when attempting to obtain an item from the pool.
SimplePool(int, SimplePool.PoolItemCallback<T>) - Constructor for class org.springframework.integration.util.SimplePool
Creates a SimplePool with a specific limit.
SimplePool.PoolItemCallback<T> - Interface in org.springframework.integration.util
User of the pool provide an implementation of this interface; called during various pool operations.
SimplePublisherMetadataSource - Class in org.springframework.integration.aop
Simple implementation of PublisherMetadataSource that allows for configuration of a single channel name, payload expression, and array of header key=value expressions.
SimplePublisherMetadataSource() - Constructor for class org.springframework.integration.aop.SimplePublisherMetadataSource
 
SimpleSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
An implementation of ReleaseStrategy that simply compares the current size of the message list to the expected 'sequenceSize'.
SimpleSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
 
SimpleToAvroTransformer - Class in org.springframework.integration.transformer
An Apache Avro transformer for generated SpecificRecord objects.
SimpleToAvroTransformer() - Constructor for class org.springframework.integration.transformer.SimpleToAvroTransformer
 
SimpleWebServiceInboundGateway - Class in org.springframework.integration.ws
 
SimpleWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
SimpleWebServiceOutboundGateway - Class in org.springframework.integration.ws
An outbound Messaging Gateway for invoking a Web Service.
SimpleWebServiceOutboundGateway(DestinationProvider) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor<?>) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor<?>, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(String) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(String, SourceExtractor<?>) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(String, SourceExtractor<?>, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWsInboundGatewaySpec - Class in org.springframework.integration.ws.dsl
SimpleWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
 
SimpleWsOutboundGatewayNoTemplateSpec() - Constructor for class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
 
SimpleWsOutboundGatewaySpec - Class in org.springframework.integration.ws.dsl
SimpleWsOutboundGatewaySpec(WebServiceTemplate) - Constructor for class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
 
SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec - Class in org.springframework.integration.ws.dsl
Spec for a SimpleWebServiceOutboundGateway where an external WebServiceTemplate is not provided.
SinglePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
SinglePatternBasedHeaderMatcher(String, boolean) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
SingleRequestResponseScenarioTests - Class in org.springframework.integration.test.support
Convenience class for a single RequestResponseScenario test
SingleRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
 
singleTerminator(byte) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
singleTerminator(byte, int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
singleUseConnections(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
This connection factory uses a new connection for each operation.
size() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
size() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
size() - Method in class org.springframework.integration.history.MessageHistory
 
size() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ArrayNodeAsList
 
SIZE - Static variable in class org.springframework.integration.mail.MailHeaders
 
size() - Method in interface org.springframework.integration.store.MessageGroup
 
size() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
size() - Method in class org.springframework.integration.store.MessageGroupQueue
 
size() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
size() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
 
skipPoll() - Method in interface org.springframework.integration.scheduling.PollSkipStrategy
Return true if this poll should be skipped.
skipPoll() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
 
skipPolls() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
Skip future polls.
skipTo(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
SmartLifecycleRoleController - Class in org.springframework.integration.support
Bulk start/stop SmartLifecycle in a particular role in phase order.
SmartLifecycleRoleController(List<String>, List<SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
Construct an instance with the provided lists of roles and lifecycles, which must be of equal length.
SmartLifecycleRoleController(MultiValueMap<String, SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
Construct an instance with the provided map of roles/instances.
smartMatch(String, String...) - Static method in class org.springframework.integration.support.utils.PatternMatchUtils
Pattern match against the supplied patterns; also supports negated ('!') patterns.
smartMatchIgnoreCase(String, String...) - Static method in class org.springframework.integration.support.utils.PatternMatchUtils
Pattern match against the supplied patterns ignoring case; also supports negated ('!') patterns.
smtp(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
SoapHeaderMapper - Interface in org.springframework.integration.ws
A convenience interface that extends RequestReplyHeaderMapper, parameterized with SoapHeader.
socket(DatagramSocket) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
socket - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
SOCKET_FACTORY_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
SOCKET_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
socketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Provide a Consumer to configure a socket with arbitrary options, like security.
socketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Provide a Consumer to configure a socket with arbitrary options, like security.
SocketCustomizer - Interface in org.springframework.integration.ip.udp
Configures a socket.
socketExpression(String) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
socketFunction(Function<Message<?>, DatagramSocket>) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
SocketInfo - Class in org.springframework.integration.ip.tcp.connection
Simple wrapper around Socket providing access to getters (except input/output streams).
SocketInfo(Socket) - Constructor for class org.springframework.integration.ip.tcp.connection.SocketInfo
 
SockJsServiceOptions() - Constructor for class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
SoftEndOfStreamException - Exception in org.springframework.integration.ip.tcp.serializer
Used to communicate that a stream has closed, but between logical messages.
SoftEndOfStreamException() - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
Default constructor.
SoftEndOfStreamException(String) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
Construct an instance with the message.
SoftEndOfStreamException(String, Throwable) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
Construct an instance with the message and cause.
soKeepAlive(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soLinger(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
soTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soTimeout(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
soTimeout(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
 
soTimeout(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
soTrafficClass(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
SOURCE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
SOURCE_DATA - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
Raw source message.
SOURCE_TYPE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
SourceCreatingTransformer - Class in org.springframework.integration.xml.transformer
Transforms the payload to a Source using a SourceFactory.
SourceCreatingTransformer() - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
SourceCreatingTransformer(SourceFactory) - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
sourceExtractor - Variable in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
 
sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Configure a SourceExtractor to use.
sourceExtractor - Variable in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
 
sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
Configure a SourceExtractor to use.
SourceFactory - Interface in org.springframework.integration.xml.source
Factory to create a Source possibly taking into account the provided message payload instance.
SourcePollingChannelAdapter - Class in org.springframework.integration.endpoint
A Channel Adapter implementation for connecting a MessageSource to a MessageChannel.
SourcePollingChannelAdapter() - Constructor for class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
SourcePollingChannelAdapterFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating a SourcePollingChannelAdapter instance.
SourcePollingChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
SourcePollingChannelAdapterSpec - Class in org.springframework.integration.dsl
 
SourcePollingChannelAdapterSpec(MessageSource<?>) - Constructor for class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
SPACE - Static variable in class org.springframework.integration.syslog.RFC5424SyslogParser
 
SPEL_PROPERTY_ACCESSOR_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
SpelExpressionRetryStateGenerator - Class in org.springframework.integration.handler.advice
Creates a DefaultRetryState from a Message.
SpelExpressionRetryStateGenerator(String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
SpelExpressionRetryStateGenerator(String, String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
SpelFunctionFactoryBean - Class in org.springframework.integration.config
A FactoryBean implementation to encapsulate the population of a static Method from the provided SpelFunctionFactoryBean.functionClass and SpelFunctionFactoryBean.functionMethodSignature as a valid StandardEvaluationContext function.
SpelFunctionFactoryBean(Class<?>, String) - Constructor for class org.springframework.integration.config.SpelFunctionFactoryBean
 
SpelFunctionParser - Class in org.springframework.integration.config.xml
Parser for the <spel-function> element.
SpelFunctionParser() - Constructor for class org.springframework.integration.config.xml.SpelFunctionParser
 
SpelPropertyAccessorRegistrar - Class in org.springframework.integration.expression
Utility class that keeps track of a Set of SpEL PropertyAccessors in order to register them with the "integrationEvaluationContext" upon initialization.
SpelPropertyAccessorRegistrar() - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
 
SpelPropertyAccessorRegistrar(PropertyAccessor...) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Create an instance with the provided property accessors.
SpelPropertyAccessorRegistrar(Map<String, PropertyAccessor>) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Create an instance with the provided named property accessors.
SpelPropertyAccessorsParser - Class in org.springframework.integration.config.xml
Parser for the <spel-property-accessors> element.
SpelPropertyAccessorsParser() - Constructor for class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
 
split() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the DefaultMessageSplitter with default options to the current integration flow position.
split(Consumer<SplitterEndpointSpec<DefaultMessageSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the DefaultMessageSplitter with provided options to the current integration flow position.
split(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ExpressionEvaluatingSplitter with provided SpEL expression.
split(String, Consumer<SplitterEndpointSpec<ExpressionEvaluatingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the ExpressionEvaluatingSplitter with provided SpEL expression.
split(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the discovered method of the service at runtime.
split(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the service at runtime.
split(Object, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(String, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the MessageProcessor at runtime from provided MessageProcessorSpec.
split(MessageProcessorSpec<?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the MessageProcessor at runtime from provided MessageProcessorSpec.
split(Class<P>, Function<P, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
split(Class<P>, Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
split(MessageHandlerSpec<?, S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(MessageHandlerSpec<?, S>, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(AbstractMessageSplitter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(S, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
splitMessage(Message<?>) - Method in class org.springframework.integration.file.splitter.FileSplitter
 
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Subclasses must override this method to split the received Message.
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
 
splitMessage(Message<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
Splitter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of splitting a single message or message payload to produce multiple messages or payloads.
splitter() - Static method in class org.springframework.integration.file.dsl.Files
The FileSplitterSpec builder factory method with default arguments.
splitter(boolean) - Static method in class org.springframework.integration.file.dsl.Files
The FileSplitterSpec builder factory method with iterator flag specified.
splitter(boolean, boolean) - Static method in class org.springframework.integration.file.dsl.Files
The FileSplitterSpec builder factory method with iterator and markers flags specified.
SplitterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Splitter.
SplitterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
 
SplitterEndpointSpec<S extends AbstractMessageSplitter> - Class in org.springframework.integration.dsl
SplitterEndpointSpec(S) - Constructor for class org.springframework.integration.dsl.SplitterEndpointSpec
 
SplitterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Splitter.
SplitterFactoryBean() - Constructor for class org.springframework.integration.config.SplitterFactoryBean
 
SplitterParser - Class in org.springframework.integration.config.xml
Parser for the <splitter/> element.
SplitterParser() - Constructor for class org.springframework.integration.config.xml.SplitterParser
 
SpringIntegrationTest - Annotation Type in org.springframework.integration.test.context
Annotation that can be specified on a test class that runs Spring Integration based tests.
SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
Collaborator for JDBC adapters which allows creation of instances of SqlParameterSource for use in update operations.
SqlServerChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
Channel message store query provider for Microsoft SQL Server / Azure SQL database.
SqlServerChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
SSL_CONTEXT_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
SSL_HANDSHAKE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
StackTraceUtils - Class in org.springframework.integration.util
Utility methods for analyzing stack traces.
STANDARD_HEADER_NAMES - Static variable in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
STANDARD_REPLY_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that only matches standard reply headers.
STANDARD_REQUEST_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that only matches standard request headers.
StandardHeaderEnricherParser - Class in org.springframework.integration.config.xml
Parser for the <header-enricher> element within the core integration namespace.
StandardHeaderEnricherParser() - Constructor for class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
StandardIntegrationFlow - Class in org.springframework.integration.dsl
The standard implementation of the IntegrationFlow interface instantiated by the Framework.
StandardIntegrationFlowContext - Class in org.springframework.integration.dsl.context
Standard implementation of IntegrationFlowContext.
StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder - Class in org.springframework.integration.dsl.context
A Builder pattern implementation for the options to register IntegrationFlow in the application context.
StandardRotationPolicy - Class in org.springframework.integration.file.remote.aop
Standard rotation policy; iterates over key/directory pairs; when the end is reached, starts again at the beginning.
StandardRotationPolicy(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>, boolean) - Constructor for class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
start() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
start() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
start() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
start() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
start() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
start() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
start() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
start() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
start() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
start() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
start() - Method in class org.springframework.integration.channel.interceptor.WireTap
Restart the wire tap if it has been stopped.
start() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
start() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
start() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Start the registration.
start() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
start() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
start() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
start() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
start() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
start() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
start() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
start() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
start() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
start() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
start() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
start() - Method in class org.springframework.integration.filter.MessageFilter
 
start() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
start() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
start() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
start() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
start() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
start() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
start() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
start() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
start() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
start() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
start() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
start() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
start() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
start() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
start() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
start() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
start() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
start() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
start() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
start() - Method in class org.springframework.integration.monitor.ManagedEndpoint
Deprecated.
 
start() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
start() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
start() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
start() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
start() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
start() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
start() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
start() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Start the registration of the LockRegistryLeaderInitiator.candidate for leader election.
start() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
 
start() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Start a sample collection.
start() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
start() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
start() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
start() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
start() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
start() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
start() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
start() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
start() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
start() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
start() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
start() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
Start the registration of the LeaderInitiator.candidate for leader election.
start() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
startAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
startConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
startLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Start all registered SmartLifecycles in the role.
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.
StaticHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
StaticHeaderValueMessageProcessor(T) - Constructor for class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
 
StaticMessageHeaderAccessor - Class in org.springframework.integration
Lightweight type-safe header accessor avoiding object creation just to access a header.
STATUS_CODE - Static variable in class org.springframework.integration.http.HttpHeaders
 
statusCodeExpression(String) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify the Expression to resolve a status code for Response to override the default '200 OK' or '500 Internal Server Error' for a timeout.
statusCodeExpression(Expression) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify the Expression to resolve a status code for Response to override the default '200 OK' or '500 Internal Server Error' for a timeout.
statusCodeFunction(Function<RequestEntity<?>, ?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify the Function to resolve a status code for Response to override the default '200 OK' or '500 Internal Server Error' for a timeout.
stderr() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the default charset encoding.
stderr(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the specified charset encoding.
stdin() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Create a source that reads from System.in.
stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Create a source that reads from System.in.
stdinPipe() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Create a source that reads from System.in.
stdinPipe(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
Create a source that reads from System.in.
stdout() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the default charset encoding.
stdout(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the specified charset encoding.
STOMP_INBOUND_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.stomp.support.StompHeaderMapper
 
STOMP_OUTBOUND_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.stomp.support.StompHeaderMapper
 
stompClient - Variable in class org.springframework.integration.stomp.AbstractStompSessionManager
 
StompConnectionFailedEvent - Class in org.springframework.integration.stomp.event
The StompIntegrationEvent implementation for the failed connection exceptions.
StompConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompConnectionFailedEvent
 
StompExceptionEvent - Class in org.springframework.integration.stomp.event
The StompIntegrationEvent implementation for the exception from STOMP Adapters.
StompExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompExceptionEvent
 
StompHeaderMapper - Class in org.springframework.integration.stomp.support
The STOMP HeaderMapper implementation.
StompHeaderMapper() - Constructor for class org.springframework.integration.stomp.support.StompHeaderMapper
 
StompInboundChannelAdapter - Class in org.springframework.integration.stomp.inbound
The MessageProducerSupport for STOMP protocol to handle STOMP frames from provided destination and send messages to the outputChannel.
StompInboundChannelAdapter(StompSessionManager, String...) - Constructor for class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
StompInboundChannelAdapterParser - Class in org.springframework.integration.stomp.config
The AbstractChannelAdapterParser implementation for the <stomp:inbound-channel-adapter/> element.
StompInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
 
StompIntegrationEvent - Class in org.springframework.integration.stomp.event
Base class for all IntegrationEvents generated by the STOMP Adapters.
StompIntegrationEvent(Object) - Constructor for class org.springframework.integration.stomp.event.StompIntegrationEvent
 
StompIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompIntegrationEvent
 
StompMessageHandler - Class in org.springframework.integration.stomp.outbound
The AbstractMessageHandler implementation to send messages to STOMP destinations.
StompMessageHandler(StompSessionManager) - Constructor for class org.springframework.integration.stomp.outbound.StompMessageHandler
 
StompNamespaceHandler - Class in org.springframework.integration.stomp.config
 
StompNamespaceHandler() - Constructor for class org.springframework.integration.stomp.config.StompNamespaceHandler
 
StompOutboundChannelAdapterParser - Class in org.springframework.integration.stomp.config
The AbstractOutboundChannelAdapterParser implementation for the <stomp:outbound-channel-adapter/> element.
StompOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompOutboundChannelAdapterParser
 
StompReceiptEvent - Class in org.springframework.integration.stomp.event
The StompIntegrationEvent for the STOMP RECEIPT Frames or lost receipts.
StompReceiptEvent(Object, String, String, StompCommand, boolean) - Constructor for class org.springframework.integration.stomp.event.StompReceiptEvent
 
StompSessionConnectedEvent - Class in org.springframework.integration.stomp.event
The StompIntegrationEvent indicating the STOMP session establishment.
StompSessionConnectedEvent(Object) - Constructor for class org.springframework.integration.stomp.event.StompSessionConnectedEvent
 
StompSessionManager - Interface in org.springframework.integration.stomp
An abstraction to manage the STOMP Session and connection/disconnection for StompSessionHandler.
stop() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
stop() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
 
stop() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
stop() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
stop() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
stop() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
stop() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
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
 
stop() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
stop(Runnable) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Stop the registration.
stop() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
stop() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
stop(Runnable) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
stop() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
stop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
stop() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
stop() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
stop() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
stop() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
stop() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
stop() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
stop() - Method in class org.springframework.integration.filter.MessageFilter
 
stop() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
 
stop() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
stop(Runnable) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
stop() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
stop() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
stop() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
stop() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Stops the server.
stop() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
stop() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
stop() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
stop() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
stop() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
stop() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
stop(Runnable) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
stop() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
stop(Runnable) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
stop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
stop() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
stop() - Method in class org.springframework.integration.monitor.ManagedEndpoint
Deprecated.
 
stop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
stop() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
stop(Runnable) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
stop() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
stop() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
stop() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
stop() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
 
stop() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Stop the registration of the LockRegistryLeaderInitiator.candidate for leader election.
stop() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
 
stop(TimerFacade) - Method in interface org.springframework.integration.support.management.metrics.SampleFacade
 
stop() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
stop() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
stop() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
stop() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
stop() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
stop() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
stop(Runnable) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
stop() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
stop(Runnable) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
stop() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
stop() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
stop() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
stop() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
stop() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
Stop the registration of the LeaderInitiator.candidate for leader election.
stop() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
stopActiveChannels() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
stopActiveComponents(long) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Shutdown active components.
stopConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
 
stopInboundMessageProducers() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Stops all inbound message producers (that are not OrderlyShutdownCapable) - may cause interrupts.
stopLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Stop all registered SmartLifecycles in the role.
stopMessageSources() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Stops all message sources - may cause interrupts.
stopped - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
store(Object, Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
store - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
StoredProcExecutor - Class in org.springframework.integration.jdbc
This class is used by all Stored Procedure (Stored Function) components and provides the core functionality to execute those.
StoredProcExecutor(DataSource) - Constructor for class org.springframework.integration.jdbc.StoredProcExecutor
Constructor taking DataSource from which the DB Connection can be obtained.
StoredProcMessageHandler - Class in org.springframework.integration.jdbc
A message handler that executes Stored Procedures for update purposes.
StoredProcMessageHandler(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcMessageHandler
Constructor passing in the StoredProcExecutor.
StoredProcMessageHandlerParser - Class in org.springframework.integration.jdbc.config
 
StoredProcMessageHandlerParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
 
StoredProcOutboundGateway - Class in org.springframework.integration.jdbc
An AbstractReplyProducingMessageHandler implementation for performing RDBMS stored procedures which return results.
StoredProcOutboundGateway(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcOutboundGateway
Constructor taking StoredProcExecutor.
StoredProcOutboundGatewayParser - Class in org.springframework.integration.jdbc.config
 
StoredProcOutboundGatewayParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
 
StoredProcParserUtils - Class in org.springframework.integration.jdbc.config
 
StoredProcPollingChannelAdapter - Class in org.springframework.integration.jdbc
A polling channel adapter that creates messages from the payload returned by executing a stored procedure or Sql function.
StoredProcPollingChannelAdapter(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
Constructor taking StoredProcExecutor.
StoredProcPollingChannelAdapterParser - Class in org.springframework.integration.jdbc.config
 
StoredProcPollingChannelAdapterParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
 
storeLock(Lock) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
 
STREAM_KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
STREAM_MESSAGE_ID - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
StreamClosedEvent - Class in org.springframework.integration.stream
Application event published when EOF is detected on a stream.
StreamClosedEvent(Object) - Constructor for class org.springframework.integration.stream.StreamClosedEvent
 
StreamNamespaceHandler - Class in org.springframework.integration.stream.config
 
StreamNamespaceHandler() - Constructor for class org.springframework.integration.stream.config.StreamNamespaceHandler
 
StreamTransformer - Class in org.springframework.integration.transformer
Transforms an InputStream payload to a byte[] or String (if a charset is provided).
StreamTransformer() - Constructor for class org.springframework.integration.transformer.StreamTransformer
Construct an instance to transform an InputStream to a byte[].
StreamTransformer(String) - Constructor for class org.springframework.integration.transformer.StreamTransformer
Construct an instance with the charset to convert the stream to a String; if null a byte[] will be produced instead.
StreamTransformerParser - Class in org.springframework.integration.config.xml
Parser for <stream-transformer/> element.
StreamTransformerParser() - Constructor for class org.springframework.integration.config.xml.StreamTransformerParser
 
STRING - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 
STRING_RESULT - Static variable in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
StringObjectMapBuilder - Class in org.springframework.integration.support
A map builder creating a map with String keys and values.
StringObjectMapBuilder() - Constructor for class org.springframework.integration.support.StringObjectMapBuilder
 
StringResultFactory - Class in org.springframework.integration.xml.result
 
StringResultFactory() - Constructor for class org.springframework.integration.xml.result.StringResultFactory
 
StringSourceFactory - Class in org.springframework.integration.xml.source
SourceFactory implementation which supports creation of a StringSource from a Document, File or String payload
StringSourceFactory() - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringSourceFactory(TransformerFactory) - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringStringMapBuilder - Class in org.springframework.integration.support
A map builder creating a map with String keys and values.
StringStringMapBuilder() - Constructor for class org.springframework.integration.support.StringStringMapBuilder
 
stringToBytes(String, String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Utility method for null-safe conversion from String to byte[]
StringValueTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
XPath MessageSelector that tests if a provided value supports payloads of type Document or String.
StringValueTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Create a selector which tests for the given value and supports multiple namespaces.
StringValueTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a single namespace Xpath selector.
StringValueTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a non-namespaced testing selector.
StringValueTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a selector with the provided XPathExpression.
STRUCTURED_DATA - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
STX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
stxetx() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the default max message size for deserialization.
stxetx(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
Return a serializer with the provided max message size for deserialization.
subFlowMapping(K, IntegrationFlow) - Method in class org.springframework.integration.dsl.RouterSpec
Add a subflow as an alternative to a RouterSpec.channelMapping(Object, String).
subject(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the subject.
SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
 
SUBJECT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
subjectExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine th subject.
subjectFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to return the subject based on the message.
subList(int, int) - Method in class org.springframework.integration.history.MessageHistory
 
SubProtocolHandlerRegistry - Class in org.springframework.integration.websocket.support
The utility class to encapsulate search algorithms for a set of provided SubProtocolHandlers.
SubProtocolHandlerRegistry(List<SubProtocolHandler>) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
 
SubProtocolHandlerRegistry(SubProtocolHandler) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
 
SubProtocolHandlerRegistry(List<SubProtocolHandler>, SubProtocolHandler) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
 
SubscribableChannelManagement - Interface in org.springframework.integration.support.management
Metrics for subscribable channels.
SubscribableJmsChannel - Class in org.springframework.integration.jms
An AbstractJmsChannel implementation for message-driven subscriptions.
SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
 
SubscribableKafkaChannel - Class in org.springframework.integration.kafka.channel
Subscribable channel backed by a Kafka topic.
SubscribableKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
Construct an instance with the provided parameters.
SubscribableRedisChannel - Class in org.springframework.integration.redis.channel
An AbstractMessageChannel implementation with BroadcastCapableChannel aspect to provide a pub-sub semantics to consume messages fgrom Redis topic.
SubscribableRedisChannel(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
subscribe(Subscriber<? super Message<?>>) - Method in class org.springframework.integration.channel.FluxMessageChannel
 
subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
Configure a IntegrationFlow to configure as a subscriber for the current BroadcastCapableChannel.
subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
subscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
subscribeSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
The Consumer callback to configure a consuming socket.
subscribeTo(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.channel.FluxMessageChannel
 
subscribeTo(Publisher<? extends Message<?>>) - Method in interface org.springframework.integration.channel.ReactiveStreamsSubscribableChannel
 
subscribeToPublisher(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
subscribeToTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
SUBSCRIPTION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
subscriptionDurable(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
subscriptionDurable(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
 
subscriptionShared(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
Set whether to make the subscription shared.
subscriptionShared(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
substituteMessageHandlerFor(String, MessageHandler) - Method in class org.springframework.integration.test.context.MockIntegrationContext
 
substituteMessageHandlerFor(String, MessageHandler, boolean) - Method in class org.springframework.integration.test.context.MockIntegrationContext
 
substituteMessageSourceFor(String, MessageSource<?>) - Method in class org.springframework.integration.test.context.MockIntegrationContext
Replace the real MessageSource in the SourcePollingChannelAdapter bean with provided MessageSource instance.
substituteMessageSourceFor(String, MessageSource<?>, boolean) - Method in class org.springframework.integration.test.context.MockIntegrationContext
Replace the real MessageSource in the SourcePollingChannelAdapter bean with provided MessageSource instance.
suffix(String) - Method in class org.springframework.integration.dsl.RouterSpec
suggestedClassName() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
SUPPLIER_GET_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The Supplier.get() method object.
SupplierExpression<T> - Class in org.springframework.integration.expression
An Expression that simply invokes Supplier.get() on its provided Supplier.
SupplierExpression(Supplier<T>) - Constructor for class org.springframework.integration.expression.SupplierExpression
 
supplyCustomHeaders(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Override to provide additional headers.
SUPPORTED_JSON_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
supports(Class<?>) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
supports(Class<?>) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
supports(HandlerResult) - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
 
supportsEventType(ResolvableType) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.CollectionArgumentResolver
 
supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.MapArgumentResolver
 
supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
 
supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.PayloadsArgumentResolver
 
supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
 
supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
 
supportsSingleFileFiltering() - Method in interface org.springframework.integration.file.filters.FileListFilter
Indicates that this filter supports filtering a single file.
supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
supportsSourceType(Class<?>) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
A boolean indicating if the KafkaProducerMessageHandler should wait for the send operation results or not.
syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
synchronizer - Variable in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
 
synchronizeToLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
synchronizeToLocalDirectory(File, int) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
synchronizeToLocalDirectory(File) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
Synchronize all available files to the local directory;
synchronizeToLocalDirectory(File, int) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
Synchronize up to maxFetchSize files to the local directory;
syndFeedInput(SyndFeedInput) - Method in class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
 
SYSLOG_PAYLOAD_ENTRIES - Static variable in class org.springframework.integration.syslog.DefaultMessageConverter
 
SyslogHeaders - Class in org.springframework.integration.syslog
Headers in a Map generated by the @link SyslogToMapTransformer that will be added to Spring Integration messages as headers, prefixed by SyslogHeaders.PREFIX.
SyslogInboundChannelAdapterParser - Class in org.springframework.integration.syslog.config
Parses a <int-syslog:inbound-channel-adapter/>.
SyslogInboundChannelAdapterParser() - Constructor for class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
 
SyslogNamespaceHandler - Class in org.springframework.integration.syslog.config
Namspace handler for spring-integration-syslog.
SyslogNamespaceHandler() - Constructor for class org.springframework.integration.syslog.config.SyslogNamespaceHandler
 
SyslogReceivingChannelAdapterFactoryBean - Class in org.springframework.integration.syslog.config
Factory bean to create syslog inbound adapters (UDP or TCP).
SyslogReceivingChannelAdapterFactoryBean(SyslogReceivingChannelAdapterFactoryBean.Protocol) - Constructor for class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
SyslogReceivingChannelAdapterFactoryBean.Protocol - Enum in org.springframework.integration.syslog.config
 
SyslogReceivingChannelAdapterSupport - Class in org.springframework.integration.syslog.inbound
Base support class for inbound channel adapters.
SyslogReceivingChannelAdapterSupport() - Constructor for class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
syslogToMap() - Static method in class org.springframework.integration.dsl.Transformers
 
SyslogToMapTransformer - Class in org.springframework.integration.transformer
Transforms a packet in Syslog (RFC3164) format to a Map.
SyslogToMapTransformer() - Constructor for class org.springframework.integration.transformer.SyslogToMapTransformer
 
SyslogToMapTransformerParser - Class in org.springframework.integration.config.xml
 
SyslogToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 

T

tableName(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Specify a table in the target database to execute the query.
tableNameExpression(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a table name at runtime against request message.
tableNameExpression(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a table name at runtime against request message.
tableNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a Function to evaluate a table name at runtime against request message.
tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
Add a tag.
tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
Add a tag.
tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
Add a tag.
tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
 
tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
 
tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
 
TAG - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
TAG - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
tailAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
Create a TailAdapterSpec builder for the FileTailingMessageProducerSupport.
TailAdapterSpec - Class in org.springframework.integration.file.dsl
A MessageProducerSpec for file tailing adapters.
TailAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.TailAdapterSpec
 
take() - Method in class org.springframework.integration.store.MessageGroupQueue
 
takeLeadership(CuratorFramework) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.LeaderListener
 
target - Variable in class org.springframework.integration.dsl.IntegrationComponentSpec
 
TASK_SCHEDULER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
TASK_SCHEDULER_POOL_SIZE - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of ThreadPoolTaskScheduler.poolSize for the taskScheduler bean initialized by the Integration infrastructure.
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.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.PollerSpec
Specify an Executor to perform the pollingTask.
taskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
Configure a task executor.
taskExecutor(Executor) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
taskExecutor(Executor) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
Specify an Executor.
taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Configure a TaskScheduler for scheduling tasks, for example in the Polling Consumer.
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
Specify a TaskScheduler for flush task when the FileExistsMode.APPEND_NO_FLUSH is in use.
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
Set a task scheduler - defaults to the integration 'taskScheduler'.
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
 
Tcp - Class in org.springframework.integration.ip.dsl
Factory methods for TCP.
TcpClientConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
TcpClientConnectionFactorySpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
 
TcpClientConnectionFactorySpec(String, int, boolean) - Constructor for class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
 
TcpCodecs - Class in org.springframework.integration.ip.tcp.serializer
Factory class to create TCP Serializer/Deserializers used to encode/decode messages to/from a TCP stream.
TcpConnection - Interface in org.springframework.integration.ip.tcp.connection
An abstraction over Socket and SocketChannel that sends Message objects by serializing the payload and streaming it to the destination.
TcpConnectionCloseEvent - Class in org.springframework.integration.ip.tcp.connection
 
TcpConnectionCloseEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionCloseEvent
 
TcpConnectionEvent - Class in org.springframework.integration.ip.tcp.connection
ApplicationEvent representing normal operations on a TcpConnection.
TcpConnectionEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
TcpConnectionEvent(TcpConnection, String, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
TcpConnectionExceptionEvent - Class in org.springframework.integration.ip.tcp.connection
ApplicationEvent representing exceptions on a TcpConnection.
TcpConnectionExceptionEvent(TcpConnection, String, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionExceptionEvent
 
TcpConnectionFactoryFactoryBean - Class in org.springframework.integration.ip.config
Instantiates a TcpN(et|io)(Server|Client)ConnectionFactory, depending on type and using-nio attributes.
TcpConnectionFactoryFactoryBean() - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
TcpConnectionFactoryFactoryBean(String) - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
TcpConnectionFactoryParser - Class in org.springframework.integration.ip.config
 
TcpConnectionFactoryParser() - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryParser
 
TcpConnectionFailedCorrelationEvent - Class in org.springframework.integration.ip.tcp.connection
An event emitted when an endpoint cannot correlate a connection id to a connection; the cause is a messaging exception with the failed message.
TcpConnectionFailedCorrelationEvent(Object, String, MessagingException) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedCorrelationEvent
 
TcpConnectionFailedEvent - Class in org.springframework.integration.ip.tcp.connection
An event emitted when a connection could not be established for some reason.
TcpConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedEvent
 
TcpConnectionInterceptor - Interface in org.springframework.integration.ip.tcp.connection
 
TcpConnectionInterceptorFactory - Interface in org.springframework.integration.ip.tcp.connection
Interface for TCP connection interceptor factories.
TcpConnectionInterceptorFactoryChain - Class in org.springframework.integration.ip.tcp.connection
 
TcpConnectionInterceptorFactoryChain() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
 
TcpConnectionInterceptorSupport - Class in org.springframework.integration.ip.tcp.connection
Base class for TcpConnectionInterceptors; passes all method calls through to the underlying TcpConnection.
TcpConnectionInterceptorSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
TcpConnectionInterceptorSupport(ApplicationEventPublisher) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
TcpConnectionOpenEvent - Class in org.springframework.integration.ip.tcp.connection
 
TcpConnectionOpenEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionOpenEvent
 
TcpConnectionServerExceptionEvent - Class in org.springframework.integration.ip.tcp.connection
IpIntegrationEvent representing exceptions on a TCP server socket/channel.
TcpConnectionServerExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionServerExceptionEvent
 
TcpConnectionServerListeningEvent - Class in org.springframework.integration.ip.tcp.connection
IpIntegrationEvent emitted when a server begins listening.
TcpConnectionServerListeningEvent(TcpServerConnectionFactory, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionServerListeningEvent
 
TcpConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
Base class for TcpConnections.
TcpConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
TcpConnectionSupport(ApplicationEventPublisher) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
TcpConnectionSupport(Socket, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Creates a TcpConnectionSupport object and publishes a TcpConnectionOpenEvent, if an event publisher is provided.
TcpDeserializationExceptionEvent - Class in org.springframework.integration.ip.tcp.serializer
Event representing an exception while decoding an incoming stream.
TcpDeserializationExceptionEvent(Object, Throwable, byte[], int) - Constructor for class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
TcpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
Channel Adapter that receives TCP stream frames and maps them to Messages.
TcpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
 
TcpInboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
TcpInboundChannelAdapterSpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
Construct an instance using an existing spring-managed connection factory.
TcpInboundChannelAdapterSpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
Construct an instance using the provided connection factory spec.
TcpInboundGateway - Class in org.springframework.integration.ip.tcp
Inbound Gateway using a server connection factory - threading is controlled by the factory.
TcpInboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpInboundGateway
 
TcpInboundGatewayParser - Class in org.springframework.integration.ip.config
 
TcpInboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
TcpInboundGatewaySpec - Class in org.springframework.integration.ip.dsl
TcpInboundGatewaySpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
Construct an instance using an existing spring-managed connection factory.
TcpInboundGatewaySpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
Construct an instance using a connection factory spec.
TcpListener - Interface in org.springframework.integration.ip.tcp.connection
Classes that implement this interface may register with a connection factory to receive messages retrieved from a TcpConnection
TcpMessageMapper - Class in org.springframework.integration.ip.tcp.connection
Maps incoming data from a TcpConnection to a Message.
TcpMessageMapper() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
TcpNetClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
A client connection factory that creates TcpNetConnections.
TcpNetClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
Creates a TcpNetClientConnectionFactory for connections to the host and port.
TcpNetConnection - Class in org.springframework.integration.ip.tcp.connection
A TcpConnection that uses and underlying Socket.
TcpNetConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Construct a TcpNetConnection for the socket.
TcpNetConnectionSupport - Interface in org.springframework.integration.ip.tcp.connection
Used by NET connection factories to instantiate a TcpNetConnection object.
TcpNetServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Implements a server connection factory that produces TcpNetConnections using a ServerSocket.
TcpNetServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
Listens for incoming connections on the port.
TcpNioClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
A client connection factory that creates TcpNioConnections.
TcpNioClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
Creates a TcpNioClientConnectionFactory for connections to the host and port.
TcpNioConnection - Class in org.springframework.integration.ip.tcp.connection
A TcpConnection that uses and underlying SocketChannel.
TcpNioConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Constructs a TcpNetConnection for the SocketChannel.
TcpNioConnectionSupport - Interface in org.springframework.integration.ip.tcp.connection
Used by NIO connection factories to instantiate a TcpNioConnection object.
TcpNioServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
/** Implements a server connection factory that produces TcpNioConnections using a ServerSocketChannel.
TcpNioServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
Listens for incoming connections on the port.
TcpNioSSLConnection - Class in org.springframework.integration.ip.tcp.connection
Implementation of TcpConnection supporting SSL/TLS over NIO.
TcpNioSSLConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String, SSLEngine) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
TcpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
 
TcpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundChannelAdapterParser
 
TcpOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
TcpOutboundChannelAdapterSpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
Construct an instance using an existing spring-managed connection factory.
TcpOutboundChannelAdapterSpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
Construct an instance using the provided connection factory spec.
TcpOutboundGateway - Class in org.springframework.integration.ip.tcp
TCP outbound gateway that uses a client connection factory.
TcpOutboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
TcpOutboundGatewayParser - Class in org.springframework.integration.ip.config
Parser for the <outbound-gateway> element of the integration 'jms' namespace.
TcpOutboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundGatewayParser
 
TcpOutboundGatewaySpec - Class in org.springframework.integration.ip.dsl
TcpOutboundGatewaySpec(AbstractClientConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Construct an instance using an existing spring-managed connection factory.
TcpOutboundGatewaySpec(TcpClientConnectionFactorySpec) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Construct an instance using the supplied connection factory spec.
TcpReceivingChannelAdapter - Class in org.springframework.integration.ip.tcp
Tcp inbound channel adapter using a TcpConnection to receive data - if the connection factory is a server factory, this Listener owns the connections.
TcpReceivingChannelAdapter() - Constructor for class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
TcpSender - Interface in org.springframework.integration.ip.tcp.connection
An interface representing a sending client of a connection factory.
TcpSendingMessageHandler - Class in org.springframework.integration.ip.tcp
Tcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections.
TcpSendingMessageHandler() - Constructor for class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
TcpServerConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
Connection factories that act as TCP servers, listening for incoming connections.
TcpServerConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
TcpServerConnectionFactorySpec(int) - Constructor for class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
 
TcpServerConnectionFactorySpec(int, boolean) - Constructor for class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
 
TcpSocketFactorySupport - Interface in org.springframework.integration.ip.tcp.connection
Strategy interface for supplying Socket Factories.
tcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
 
TcpSocketSupport - Interface in org.springframework.integration.ip.tcp.connection
Strategy interface for modifying sockets.
TcpSSLContextSupport - Interface in org.springframework.integration.ip.tcp.connection
Strategy interface for the creation of an SSLContext object for use with SSL/TLS sockets.
TcpSyslogReceivingChannelAdapter - Class in org.springframework.integration.syslog.inbound
TCP implementation of a syslog inbound channel adapter.
TcpSyslogReceivingChannelAdapter() - Constructor for class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
template - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
templateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
Configure channelTransacted on the RabbitTemplate used when sending messages to the channel.
temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Set the temporary suffix to use when transferring files to the remote system.
temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
By default, every file that is in the process of being transferred will appear in the file system with an additional suffix, which by default is .writing.
temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
Configure a suffix to temporarily apply to the local filename; when copied the file is renamed to its final name.
temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set the temporary suffix to use when transferring files to the remote system.
temporaryRemoteDirectory(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote directory path.
temporaryRemoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote temporary directory path Function.
temporaryRemoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
Specify a remote directory path SpEL expression.
temporaryRemoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set a temporary remote directory expression; used when transferring files to the remote system.
temporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set a temporary remote directory expression; used when transferring files to the remote system.
temporaryRemoteDirectoryFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set a temporary remote directory function; used when transferring files to the remote system.
test() - Method in interface org.springframework.integration.file.remote.session.Session
Test the session is still alive, e.g.
test() - Method in class org.springframework.integration.ftp.session.FtpSession
 
test() - Method in class org.springframework.integration.sftp.session.SftpSession
 
test(Message<?>) - Method in class org.springframework.integration.test.predicate.MessagePredicate
 
TestingUtilities - Class in org.springframework.integration.ip.util
Convenience class providing methods for testing IP components.
TestMailServer - Class in org.springframework.integration.test.mail
A basic test mail server for pop3, imap, Serves up a canned email message with each protocol.
TestMailServer.ImapServer - Class in org.springframework.integration.test.mail
 
TestMailServer.MailServer - Class in org.springframework.integration.test.mail
 
TestMailServer.MailServer.MailHandler - Class in org.springframework.integration.test.mail
 
TestMailServer.Pop3Server - Class in org.springframework.integration.test.mail
 
TestMailServer.SmtpServer - Class in org.springframework.integration.test.mail
 
testRequestResponseScenarios() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
Execute each scenario.
TestUtils - Class in org.springframework.integration.test.util
 
TestUtils() - Constructor for class org.springframework.integration.test.util.TestUtils
 
TestUtils.LevelsContainer - Class in org.springframework.integration.test.util
 
TestUtils.TestApplicationContext - Class in org.springframework.integration.test.util
A GenericApplicationContext extension with some support methods to register Spring Integration beans in the application context at runtime.
THREAD - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
ThreadAffinityClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
A client connection factory that binds a connection to a thread.
ThreadAffinityClientConnectionFactory(AbstractClientConnectionFactory) - Constructor for class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
ThreadStatePropagationChannelInterceptor<S> - Class in org.springframework.integration.channel.interceptor
The ExecutorChannelInterceptor implementation responsible for the Thread (any?) state propagation from one message flow's thread to another through the MessageChannels involved in the flow.
ThreadStatePropagationChannelInterceptor() - Constructor for class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
THROW_EXCEPTION_ON_LATE_REPLY - Static variable in class org.springframework.integration.context.IntegrationProperties
throwExceptionOnRejection(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
The default value is false meaning that rejected Messages will be quietly dropped or sent to the discard channel if available.
timeout(long) - Method in class org.springframework.integration.dsl.WireTapSpec
 
timeout(int) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
TimeoutCountSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that releases all messages if any of the following is true: The sequence is complete (if there is one). There are more messages than a threshold set by the user. The time elapsed since the earliest message, according to their timestamps, if present, exceeds a timeout set by the user.
TimeoutCountSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
TimeoutCountSequenceSizeReleaseStrategy(int, long) - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
timerBuilder(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Create a timer builder for a timer with the provided name.
timerBuilder(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
TimerFacade - Interface in org.springframework.integration.support.management.metrics
 
TimerStats - Class in org.springframework.integration.graph
Statistics captured from a timer meter.
TimerStats(long, double, double) - Constructor for class org.springframework.integration.graph.TimerStats
 
timestamp(Function<Message<P>, Long>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at runtime to determine the Kafka record timestamp will be stored in the topic.
TIMESTAMP - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
TIMESTAMP - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
TIMESTAMP_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
timestampExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the timestamp at runtime against a request Message as a root object of evaluation context.
timestampExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the timestamp at runtime against a request Message as a root object of evaluation context.
timeToLive(int) - Method in class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
 
timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
timeToLiveExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Specify a SpEL expression to evaluate a timeToLive for JMS message to send.
timeToLiveFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
Specify a Function to resolve a timeToLive for JMS message to send.
to(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the To: addresses.
TO - Static variable in class org.springframework.integration.mail.MailHeaders
 
TO - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
TO_STRING_FRIENDLY_JSON_NODE_TO_STRING_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
toArray() - Method in class org.springframework.integration.history.MessageHistory
 
toArray(T[]) - Method in class org.springframework.integration.history.MessageHistory
 
toByteArrayTransformer() - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToByteArrayTransformer instance.
toByteArrayTransformer(boolean) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToByteArrayTransformer instance.
toCommand(String) - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
 
toExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set the expression that will be evaluated to determine the To: addresses.
toFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
Set a function that will be invoked to determine the To: addresses based on the message.
toHeaders(HttpHeaders) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Map from an HttpHeaders instance to integration MessageHeaders.
toHeaders(Message) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
 
toHeaders(MimeMessage) - Method in class org.springframework.integration.mail.support.DefaultMailHeaderMapper
 
toHeaders(T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
toHeaders(StompHeaders) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
 
toHeadersFromReply(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
toHeadersFromReply(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given reply object to abstracted MessageHeaders.
toHeadersFromRequest(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
toHeadersFromRequest(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
toHeadersFromRequest(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given request object to abstracted MessageHeaders.
toJson() - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(String) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(JsonObjectMapper<?, ?>, String) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(ObjectToJsonTransformer.ResultType) - Static method in class org.springframework.integration.dsl.Transformers
Factory for the ObjectToJsonTransformer based on the provided ObjectToJsonTransformer.ResultType.
toJson(ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.Transformers
 
toJson() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
toJson(Object, String...) - Static method in class org.springframework.integration.json.SimpleJsonSerializer
Convert the bean to JSON with the provided properties.
toJson(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJson(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJson(Object, Writer) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJsonNode(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toMap() - Static method in class org.springframework.integration.dsl.Transformers
 
toMap(boolean) - Static method in class org.springframework.integration.dsl.Transformers
 
toMap(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
 
toMap(JsonObjectMapper<?, ?>, boolean) - Static method in class org.springframework.integration.dsl.Transformers
 
toMap() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.codec.CodecMessageConverter
 
toMessage(TcpConnection, Map<String, Object>) - Method in class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
 
toMessage(TcpConnection, Map<String, Object>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
toMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
toMessage(DatagramPacket, Map<String, Object>) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
toMessage(byte[]) - Method in interface org.springframework.integration.mapping.BytesMessageMapper
 
toMessage(byte[], Map<String, Object>) - Method in interface org.springframework.integration.mapping.BytesMessageMapper
 
toMessage(byte[], Map<String, Object>) - Method in class org.springframework.integration.mapping.ConvertingBytesMessageMapper
 
toMessage(T) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
Convert a provided object to the Message.
toMessage(T, Map<String, Object>) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
Convert a provided object to the Message and supply with headers if necessary and provided.
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
toMessage(String, MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
toMessage(String, MqttMessage) - Method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
Convert to a Message.
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
toMessage(byte[], Map<String, Object>) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
 
toMessage(String, Map<String, Object>) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
toMessageBuilder(String, MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
toMessageBuilder(String, MqttMessage) - Method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
Convert to a message builder.
toOption(String) - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
 
toPasswordProtectedString(URLName) - Static method in class org.springframework.integration.mail.MailTransportUtils
Returns a string representation of the given URLName, where the password has been protected.
topic - Variable in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 
topic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure the Kafka topic to send messages.
topic(Function<Message<P>, String>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at runtime to determine the topic to which a message will be sent.
TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
topic(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Specify a topic the SocketType.PUB socket is going to use for distributing messages into the subscriptions.
TOPIC - Static variable in class org.springframework.integration.zeromq.ZeroMqHeaders
A ZeroMq pub/sub message topic header.
topicExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
topicExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
topicExpression(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Specify a SpEL expression to evaluate a topic a SocketType.PUB is going to use for distributing messages into the subscriptions.It is ignored for all other SocketTypes supported.
topicExpression(Expression) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Specify a SpEL expression to evaluate a topic a SocketType.PUB is going to use for distributing messages into the subscriptions.It is ignored for all other SocketTypes supported.
topicFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Specify a Function to evaluate a topic a SocketType.PUB is going to use for distributing messages into the subscriptions.It is ignored for all other SocketTypes supported.
topicLock - Variable in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
topics(String...) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
Specify topics the SocketType.SUB socket is going to use for subscription.
toPublisher(MessageChannel) - Static method in class org.springframework.integration.channel.MessageChannelReactiveUtils
Deprecated.
 
toReactivePublisher() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Represent an Integration Flow as a Reactive Streams Publisher bean.
toReactivePublisher() - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
 
toSoapHeaders(WebServiceMessage, Message<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
toString() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
toString() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
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
 
toString() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
toString() - Method in class org.springframework.integration.channel.NullChannel
 
toString() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
toString() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
toString() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
toString() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
toString() - Method in class org.springframework.integration.events.IntegrationEvent
 
toString() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
toString() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
toString() - Method in class org.springframework.integration.expression.ValueExpression
 
toString() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
toString() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
toString() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
toString() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
toString() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
 
toString() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingIdleEvent
 
toString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
toString() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
 
toString() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
toString() - Method in class org.springframework.integration.ftp.server.FileWrittenEvent
 
toString() - Method in class org.springframework.integration.ftp.server.FtpRequestEvent
 
toString() - Method in class org.springframework.integration.ftp.server.PathRemovedEvent
 
toString() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
 
toString() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
toString() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
toString() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
 
toString() - Method in class org.springframework.integration.history.MessageHistory
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionCloseEvent
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedCorrelationEvent
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionOpenEvent
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
toString() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
toString() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
toString() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
toString() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
toString() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
toString() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
toString() - Method in class org.springframework.integration.leader.DefaultCandidate
 
toString() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
 
toString() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
toString() - Method in class org.springframework.integration.message.AdviceMessage
 
toString() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveredEvent
 
toString() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
toString() - Method in class org.springframework.integration.mqtt.event.MqttSubscribedEvent
 
toString() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
toString() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
toString() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
toString() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
toString() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
toString() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
toString() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
 
toString() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
 
toString() - Method in class org.springframework.integration.sftp.server.SessionClosedEvent
 
toString() - Method in class org.springframework.integration.sftp.server.SessionOpenedEvent
 
toString() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
toString() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
toString() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
toString() - Method in class org.springframework.integration.support.MutableMessage
 
toString() - Method in exception org.springframework.integration.support.PartialSuccessException
 
toString() - Method in class org.springframework.integration.util.UpperBound
 
toStringTransformer() - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToStringTransformer instance with default charset and no delete files afterwards.
toStringTransformer(boolean) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToStringTransformer instance with default charset and with delete files flag.
toStringTransformer(String) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToStringTransformer instance with provided charset and no delete files afterwards.
toStringTransformer(String, boolean) - Static method in class org.springframework.integration.file.dsl.Files
Create a FileToStringTransformer instance with provided charset and delete files flag.
toStringTransformer() - Static method in class org.springframework.integration.mail.dsl.Mail
toStringTransformer(String) - Static method in class org.springframework.integration.mail.dsl.Mail
trace() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
The factory to produce Log4j2LevelAdjuster instances for Level.TRACE logging with the org.springframework.integration as default category.
TrackableComponent - Interface in org.springframework.integration.support.management
 
transacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
 
transactional(TransactionManager) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the MessageHandler.
transactional(TransactionManager, boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the MessageHandler.
transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
transactional() - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the MessageHandler.
transactional(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the MessageHandler.
transactional(TransactionManager) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the pollingTask.
transactional() - Method in class org.springframework.integration.dsl.PollerSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the pollingTask.
transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a TransactionInterceptor Advice for the pollingTask.
transactional(TransactionManager) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Specify a TransactionInterceptor Advice with the provided TransactionManager and default DefaultTransactionAttribute for the downstream flow.
transactional(TransactionInterceptor) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Specify a TransactionInterceptor Advice for the downstream flow.
transactional() - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the downstream flow.
transactionalRelease() - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
transactionalRelease(TransactionInterceptor) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
transactionalRelease(TransactionManager) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
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
transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
TransactionHandleMessageAdvice - Class in org.springframework.integration.transaction
TransactionHandleMessageAdvice() - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
 
TransactionHandleMessageAdvice(TransactionManager, Properties) - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
 
TransactionHandleMessageAdvice(TransactionManager, TransactionAttributeSource) - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
 
TransactionInterceptorBuilder - Class in org.springframework.integration.transaction
Provides a fluent API to build a transaction interceptor.
TransactionInterceptorBuilder() - Constructor for class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
TransactionInterceptorBuilder(boolean) - Constructor for class org.springframework.integration.transaction.TransactionInterceptorBuilder
 
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).
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
transactionManager(TransactionManager) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
Provide a TransactionManager instance to use.
transactionName(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
A name for transaction.
transactionName(String) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.dsl.PollerSpec
Specify the TransactionSynchronizationFactory to attach a TransactionSynchronization to the transaction around poll operation.
transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
TransactionSynchronizationFactory - Interface in org.springframework.integration.transaction
Strategy for implementing factories that create TransactionSynchronization
TransactionSynchronizationFactoryBean - Class in org.springframework.integration.transaction
The FactoryBean implementation (with Builder style) to be used from JavaConfig to populate DefaultTransactionSynchronizationFactory bean.
TransactionSynchronizationFactoryBean() - Constructor for class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
TransactionSynchronizationFactoryParser - Class in org.springframework.integration.config.xml
Parser for transaction-synchronizatioin-factory element
TransactionSynchronizationFactoryParser() - Constructor for class org.springframework.integration.config.xml.TransactionSynchronizationFactoryParser
 
TransactionSynchronizationProcessor - Interface in org.springframework.integration.transaction
Strategy for implementing transaction synchronization processors
transactionTimeout(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
A transaction timeout.
transactionTimeout(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
transferCookies(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Set to true if you wish Set-Cookie header in response to be transferred as Cookie header in subsequent interaction for a message.
transferTo(File) - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
transform(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Transformer EI Pattern specific MessageHandler implementation for the SpEL Expression.
transform(String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Transformer EI Pattern specific MessageHandler implementation for the SpEL Expression.
transform(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the discovered service method at runtime.
transform(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the service method at runtime.
transform(Object, String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the service method at runtime.
transform(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the MessageProcessor from provided MessageProcessorSpec.
transform(MessageProcessorSpec<?>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the MessageProcessor from provided MessageProcessorSpec.
transform(Class<P>, GenericTransformer<P, T>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer for the specific payloadType to convert at runtime.
transform(Class<P>, GenericTransformer<P, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer for the specific payloadType to convert at runtime.
transform(GenericTransformer<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer.
transform(GenericTransformer<S, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer.
transform(Message<?>) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
 
transform(S) - Method in interface org.springframework.integration.transformer.GenericTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderFilter
 
transform(Message<?>) - Method in interface org.springframework.integration.transformer.Transformer
 
Transformer - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of transforming a message, message header, or message payload.
Transformer - Interface in org.springframework.integration.transformer
Strategy interface for transforming a Message.
TRANSFORMER_TRANSFORM_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
The org.springframework.integration.transformer.GenericTransformer#transform(Object) method object.
TransformerAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with a @Transformer.
TransformerAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
 
TransformerFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Transformer.
TransformerFactoryBean() - Constructor for class org.springframework.integration.config.TransformerFactoryBean
 
transformerHelper - Variable in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
TransformerParser - Class in org.springframework.integration.config.xml
Parser for the <transformer/> element.
TransformerParser() - Constructor for class org.springframework.integration.config.xml.TransformerParser
 
Transformers - Class in org.springframework.integration.dsl
An utility class to provide methods for out-of-the-box Transformers.
Transformers() - Constructor for class org.springframework.integration.dsl.Transformers
 
transformFile(File) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
Subclasses must implement this method to transform the File contents.
transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToByteArrayTransformer
 
transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.EncodingPayloadTransformer
 
transformPayload(Map<?, ?>) - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.SyslogToMapTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
transformResult(Result) - Method in interface org.springframework.integration.xml.transformer.ResultTransformer
 
trigger(Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
trigger(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction.
trigger(String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction and endpoint options from GenericEndpointSpec.
trigger(MessageTriggerAction) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction.
trigger(MessageTriggerAction, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction and endpoint options from GenericEndpointSpec.
trigger(Trigger) - Method in class org.springframework.integration.dsl.PollerFactory
 
trigger(Trigger) - Static method in class org.springframework.integration.dsl.Pollers
 
trigger(Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
When using FileExistsMode.APPEND_NO_FLUSH, you can send a message to this method to flush any file(s) that needs it.
trigger(Message<?>) - Method in interface org.springframework.integration.handler.MessageTriggerAction
Take some action based on the message.
tryAcquire(long) - Method in class org.springframework.integration.util.UpperBound
Acquires a permit from the underlying semaphore if this UpperBound is bounded and returns true if it succeeds within the given timeout.
tryClaim(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
This class takes the minimal implementation and merely delegates to the locker if set.
tryClaim(File) - Method in interface org.springframework.integration.file.DirectoryScanner
Claim the file to process.
tryOptimizedDispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
TYPE - Static variable in class org.springframework.integration.transformer.support.AvroHeaders
The SpecificRecord type.
TYPE - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
TYPE_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
typeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
Set the expression to evaluate against the message to determine the type.
typeExpression(String) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
Set the expression to evaluate against the message to determine the type id.
typeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
Set the expression to evaluate against the message to determine the value for the AvroHeaders.TYPE header.
typeExpression(String) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
Set the expression to evaluate against the message to determine the value for the AvroHeaders.TYPE header.

U

Udp - Class in org.springframework.integration.ip.dsl
Factory methods for UDP.
UDP_SOCKET_CUSTOMIZER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
UdpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
Channel Adapter that receives UDP datagram packets and maps them to Messages.
UdpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
 
UdpInboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
UdpInboundChannelAdapterSpec(int) - Constructor for class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
UdpInboundChannelAdapterSpec(int, String) - Constructor for class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
 
UdpMulticastOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
UdpMulticastOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
 
UdpMulticastOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
 
UdpMulticastOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
 
UdpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
 
UdpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
 
UdpServerListeningEvent - Class in org.springframework.integration.ip.udp
IpIntegrationEvent emitted when a server begins listening.
UdpServerListeningEvent(Object, int) - Constructor for class org.springframework.integration.ip.udp.UdpServerListeningEvent
 
UdpSyslogReceivingChannelAdapter - Class in org.springframework.integration.syslog.inbound
UDP implementation of a syslog inbound channel adapter.
UdpSyslogReceivingChannelAdapter() - Constructor for class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
UdpUnicastOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
UdpUnicastOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
 
UdpUnicastOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
 
UdpUnicastOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
 
unbound() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
UNDECODED - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
UNDECODED - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
UnexpiredMessageSelector - Class in org.springframework.integration.selector
A MessageSelector that accepts Messages that are not yet expired.
UnexpiredMessageSelector() - Constructor for class org.springframework.integration.selector.UnexpiredMessageSelector
 
ungetc() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
UnicastingDispatcher - Class in org.springframework.integration.dispatcher
Implementation of MessageDispatcher that will attempt to send a Message to at most one of its handlers.
UnicastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UnicastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UnicastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
A channel adapter to receive incoming UDP packets.
UnicastReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Constructs a UnicastReceivingChannelAdapter that listens on the specified port.
UnicastReceivingChannelAdapter(int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Constructs a UnicastReceivingChannelAdapter that listens for packets on the specified port.
UnicastSendingMessageHandler - Class in org.springframework.integration.ip.udp
A MessageHandler implementation that maps a Message into a UDP datagram packet and sends that to the specified host and port.
UnicastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Basic constructor; no reliability; no acknowledgment.
UnicastSendingMessageHandler(String) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Construct UnicastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
UnicastSendingMessageHandler(Expression) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Construct UnicastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
UnicastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Can used to add a length to each packet which can be checked at the destination.
UnicastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Add an acknowledgment request to packets.
UnicastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Add a length and/or acknowledgment request to packets.
UniqueExpiryCallback - Interface in org.springframework.integration.store
A marker interface extension of the MessageGroupStore.MessageGroupCallback for components which should be registered in the MessageGroupStore only once.
UniqueMethodFilter - Class in org.springframework.integration.util
 
UniqueMethodFilter(Class<?>) - Constructor for class org.springframework.integration.util.UniqueMethodFilter
 
unlock(File) - Method in interface org.springframework.integration.file.FileLocker
Unlocks the given file.
unlock(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
 
unmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
Specify an unmarshaller to use.
unmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
Configure the unmarshaller to use.
UnmarshallingTransformer - Class in org.springframework.integration.xml.transformer
An implementation of Transformer that delegates to an OXM Unmarshaller.
UnmarshallingTransformer(Unmarshaller) - Constructor for class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
UnmarshallingTransformerParser - Class in org.springframework.integration.xml.config
 
UnmarshallingTransformerParser() - Constructor for class org.springframework.integration.xml.config.UnmarshallingTransformerParser
 
unregisterSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Unregister a TcpSender.
unsolictedMessageChannelName(String) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Set the unsolicited message channel name.
unsolictedMessageChannelName(MessageChannel) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
Set the unsolicited message channel.
unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
 
unsubscribeFromTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
unwrapExceptionIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
unwrapThrowableIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
updateAckAddress() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
updateNotPropagatedHeaders(String[], boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Set or replace not propagated headers.
updateSql(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
Configure an update query.
updatingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for request-reply gateway based on the provided EntityManagerFactory.
updatingGateway(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for request-reply gateway based on the provided EntityManager.
updatingGateway(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
Create a JpaUpdatingOutboundEndpointSpec builder instance for request-reply gateway based on the provided JpaOperations.
UpdatingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
The Parser for Updating JPA Outbound Gateway.
UpdatingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.UpdatingJpaOutboundGatewayParser
 
UploadedMultipartFile - Class in org.springframework.integration.http.multipart
A MultipartFile implementation that represents an uploaded File.
UploadedMultipartFile(File, long, String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
 
UploadedMultipartFile(byte[], String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
 
UpperBound - Class in org.springframework.integration.util
Thin wrapper around a Semaphore that allows to create a potentially unlimited upper bound to by used in buffers of messages (e.g.
UpperBound(int) - Constructor for class org.springframework.integration.util.UpperBound
Create an UpperBound with the given capacity.
uri - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
uri(String) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Configure with a URI.
uriFactory - Variable in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
uriFactory - Variable in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
uriVariable(String, Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify an Expression to evaluate a value for the uri template variable.
uriVariable(String, String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a value SpEL expression for the uri template variable.
uriVariable(String, Function<Message<P>, ?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a Function to evaluate a value for the uri template variable.
uriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
uriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
uriVariablesExpression(String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a SpEL expression to evaluate a Map of URI variables at runtime against request message.
uriVariablesExpression(Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a SpEL expression to evaluate a Map of URI variables at runtime against request message.
uriVariablesFunction(Function<Message<P>, Map<String, ?>>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a Function to evaluate a Map of URI variables at runtime against request message.
useFlowIdAsPrefix() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
Invoke this method to prefix bean names in the flow with the (required) flow id and a period.
useFlowIdAsPrefix() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
 
usePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Indicates that whether only the payload of the passed in Message will be used as a source of parameters.
USER_PRINCIPAL - Static variable in class org.springframework.integration.http.HttpHeaders
 
userFlag(String) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default .
userFlag(String) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default .
UseSpelInvoker - Annotation Type in org.springframework.integration.annotation
Indicates that a POJO handler method (@ServiceActivator, @Transformer, etc., or such methods invoked from XML definitions) should be invoked using SpEL.
useTemporaryFileName(boolean) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
A boolean flag to use temporary files names or not.
useTemporaryFileName(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
Set whether a temporary file name is used when sending files to the remote system.
useWatchService(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
Switch this FileReadingMessageSource to use its internal WatchService directory scanner.
usingCallback(ExpressionEvalMap.EvaluationCallback) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
usingEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
usingEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
usingSimpleCallback() - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
uuid - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
UUIDConverter - Class in org.springframework.integration.util
Utility to help generate UUID instances from generic objects.
UUIDConverter() - Constructor for class org.springframework.integration.util.UUIDConverter
 

V

validate(Object) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
validateMessage(Message<?>) - Method in class org.springframework.integration.test.support.MessageValidator
Implement this method to validate the message
validateResponse(T) - Method in class org.springframework.integration.test.support.AbstractResponseValidator
Implement this method to validate the response (Message or Payload)
validateResponse(Message<?>) - Method in class org.springframework.integration.test.support.MessageValidator
 
validator(Validator) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify a Validator to validate a converted payload from request.
ValueExpression<V> - Class in org.springframework.integration.expression
A very simple hardcoded implementation of the Expression interface that represents an immutable value.
ValueExpression(V) - Constructor for class org.springframework.integration.expression.ValueExpression
 
valueOf(String) - Static method in enum org.springframework.integration.acks.AcknowledgmentCallback.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.file.FileReadingMessageSource.WatchEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.file.splitter.FileSplitter.FileMarker.Mark
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.file.support.FileExistsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.ftp.session.FtpRemoteFileTemplate.ExistsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.gemfire.inbound.CqEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.gemfire.inbound.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.graph.LinkNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.handler.LoggingHandler.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.IntegrationPatternType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.jpa.support.OutboundGatewayType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.jpa.support.PersistMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.json.ObjectToJsonTransformer.ResultType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.mqtt.core.ConsumerStopAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.rsocket.RSocketInteractionModel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.sftp.session.JschProxyFactoryBean.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.xml.selector.XmlValidatingMessageSelector.SchemaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.zeromq.ZeroMqProxy.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.integration.acks.AcknowledgmentCallback.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
values() - Static method in enum org.springframework.integration.file.FileReadingMessageSource.WatchEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.file.splitter.FileSplitter.FileMarker.Mark
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.file.support.FileExistsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.ftp.session.FtpRemoteFileTemplate.ExistsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.gemfire.inbound.CqEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.gemfire.inbound.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.graph.LinkNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.handler.LoggingHandler.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.IntegrationPatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.jpa.support.OutboundGatewayType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.jpa.support.PersistMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.json.ObjectToJsonTransformer.ResultType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.mqtt.core.ConsumerStopAction
Returns an array containing the constants of this enum type, in the order they are declared.
values(Function<Message<P>, Map<String, ?>>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a Function to evaluate a Map for name-value pairs to bind as parameters into a query.
values(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a Map for name-value pairs to bind as parameters into a query.
values(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
Set a SpEL expression to evaluate a Map for name-value pairs to bind as parameters into a query.
values() - Static method in enum org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.rsocket.RSocketInteractionModel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.sftp.session.JschProxyFactoryBean.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.xml.selector.XmlValidatingMessageSelector.SchemaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.zeromq.ZeroMqProxy.Type
Returns an array containing the constants of this enum type, in the order they are declared.
variable(String, Object) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
The script variable to use.
variable(String, Object) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
The script variable to use.
variableGenerator(ScriptVariableGenerator) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
variableGenerator(ScriptVariableGenerator) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
variables(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
The script variables to use.
variables(Map<String, Object>) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
The script variables to use.
variables(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
The script variables to use.
variables(Map<String, Object>) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
The script variables to use
verifyResultCollectionConsistsOfMessages(Collection<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
verifyType(String, Object) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
VERSION - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
VetoCapableInterceptor - Interface in org.springframework.integration.channel.interceptor
ChannelInterceptors implementing this interface can veto global interception of a particular channel.

W

waitForConfirm(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
Wait for a publisher confirm.
waitForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
This method is unique to the IMAP receiver and only works if IMAP IDLE is supported (see RFC 2177 for more detail).
waitListening(AbstractServerConnectionFactory, Long) - Static method in class org.springframework.integration.ip.util.TestingUtilities
Wait for a server connection factory to actually start listening before starting a test.
waitListening(AbstractInternetProtocolReceivingChannelAdapter, Long) - Static method in class org.springframework.integration.ip.util.TestingUtilities
Wait for a server connection factory to actually start listening before starting a test.
waitStopListening(AbstractServerConnectionFactory, Long) - Static method in class org.springframework.integration.ip.util.TestingUtilities
Wait for a server connection factory to stop listening.
waitUntilFactoryHasThisNumberOfConnections(AbstractConnectionFactory, int) - Static method in class org.springframework.integration.ip.util.TestingUtilities
Wait for up to 10 seconds for the connection factory to have the specified number of connections.
was(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
watchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
The WatchService event types.
WEB_FLUX_PRESENT - Static variable in class org.springframework.integration.http.config.HttpContextUtils
A boolean flag to indicate if the org.springframework.web.reactive.DispatcherHandler is present in the CLASSPATH to allow the registration of Integration server reactive components, e.g.
WEB_MVC_PRESENT - Static variable in class org.springframework.integration.http.config.HttpContextUtils
A boolean flag to indicate if the org.springframework.web.servlet.DispatcherServlet is present in the CLASSPATH to allow the registration of Integration server components, e.g.
webClient - Variable in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
WebFlux - Class in org.springframework.integration.webflux.dsl
The WebFlux components Factory.
WebFluxContextUtils - Class in org.springframework.integration.webflux.support
Utility class for accessing WebFlux integration components from the BeanFactory.
WebFluxInboundEndpoint - Class in org.springframework.integration.webflux.inbound
A MessagingGatewaySupport implementation for Spring WebFlux HTTP requests execution.
WebFluxInboundEndpoint() - Constructor for class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
 
WebFluxInboundEndpoint(boolean) - Constructor for class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
 
WebFluxInboundEndpointParser - Class in org.springframework.integration.webflux.config
 
WebFluxInboundEndpointParser(boolean) - Constructor for class org.springframework.integration.webflux.config.WebFluxInboundEndpointParser
 
WebFluxInboundEndpointSpec - Class in org.springframework.integration.webflux.dsl
WebFluxInboundEndpointSpec(WebFluxInboundEndpoint, String...) - Constructor for class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
 
WebFluxIntegrationConfigurationInitializer - Class in org.springframework.integration.webflux.config
The WebFlux Integration infrastructure beanFactory initializer.
WebFluxIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.webflux.config.WebFluxIntegrationConfigurationInitializer
 
WebFluxIntegrationRequestMappingHandlerMapping - Class in org.springframework.integration.webflux.inbound
The HandlerMapping implementation that detects and registers RequestMappingInfos for HttpRequestHandlingEndpointSupport from a Spring Integration HTTP configuration of <inbound-channel-adapter/> and <inbound-gateway/> elements.
WebFluxIntegrationRequestMappingHandlerMapping() - Constructor for class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
 
WebFluxMessageHandlerSpec - Class in org.springframework.integration.webflux.dsl
WebFluxMessageHandlerSpec(URI, WebClient) - Constructor for class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
WebFluxMessageHandlerSpec(String, WebClient) - Constructor for class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
WebFluxMessageHandlerSpec(Expression, WebClient) - Constructor for class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
WebFluxNamespaceHandler - Class in org.springframework.integration.webflux.config
Namespace handler for Spring Integration's webflux namespace.
WebFluxNamespaceHandler() - Constructor for class org.springframework.integration.webflux.config.WebFluxNamespaceHandler
 
WebFluxOutboundChannelAdapterParser - Class in org.springframework.integration.webflux.config
Parser for the 'outbound-channel-adapter' element of the webflux namespace.
WebFluxOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.webflux.config.WebFluxOutboundChannelAdapterParser
 
WebFluxOutboundGatewayParser - Class in org.springframework.integration.webflux.config
Parser for the 'outbound-gateway' element of the webflux namespace.
WebFluxOutboundGatewayParser() - Constructor for class org.springframework.integration.webflux.config.WebFluxOutboundGatewayParser
 
WebFluxRequestExecutingMessageHandler - Class in org.springframework.integration.webflux.outbound
A MessageHandler implementation that executes HTTP requests by delegating to a Reactive WebClient instance.
WebFluxRequestExecutingMessageHandler(URI) - Constructor for class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI.
WebFluxRequestExecutingMessageHandler(String) - Constructor for class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI.
WebFluxRequestExecutingMessageHandler(Expression) - Constructor for class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI Expression.
WebFluxRequestExecutingMessageHandler(String, WebClient) - Constructor for class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI using a provided WebClient.
WebFluxRequestExecutingMessageHandler(Expression, WebClient) - Constructor for class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
Create a handler that will send requests to the provided URI using a provided WebClient.
WebServiceHeaderEnricherParser - Class in org.springframework.integration.ws.config
 
WebServiceHeaderEnricherParser() - Constructor for class org.springframework.integration.ws.config.WebServiceHeaderEnricherParser
 
WebServiceHeaders - Class in org.springframework.integration.ws
Pre-defined header names to be used when storing or retrieving Web Service properties to/from integration Message Headers.
WebServiceHeaders() - Constructor for class org.springframework.integration.ws.WebServiceHeaders
 
WebServiceInboundGatewayParser - Class in org.springframework.integration.ws.config
 
WebServiceInboundGatewayParser() - Constructor for class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
webServiceMessageFactory - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
WebServiceOutboundGatewayParser - Class in org.springframework.integration.ws.config
Parser for the <outbound-gateway/> element in the 'ws' namespace.
WebServiceOutboundGatewayParser() - Constructor for class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
webSocketHandler - Variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
WebSocketInboundChannelAdapter - Class in org.springframework.integration.websocket.inbound
 
WebSocketInboundChannelAdapter(IntegrationWebSocketContainer) - Constructor for class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
WebSocketInboundChannelAdapter(IntegrationWebSocketContainer, SubProtocolHandlerRegistry) - Constructor for class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
WebSocketInboundChannelAdapterParser - Class in org.springframework.integration.websocket.config
The AbstractChannelAdapterParser implementation for the <int-websocket:inbound-channel-adapter/> element.
WebSocketInboundChannelAdapterParser() - Constructor for class org.springframework.integration.websocket.config.WebSocketInboundChannelAdapterParser
 
WebSocketIntegrationConfigurationInitializer - Class in org.springframework.integration.websocket.config
The WebSocket Integration infrastructure beanFactory initializer.
WebSocketIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.websocket.config.WebSocketIntegrationConfigurationInitializer
 
WebSocketListener - Interface in org.springframework.integration.websocket
A contract for handling incoming WebSocketMessages messages as part of a higher level protocol, referred to as "sub-protocol" in the WebSocket RFC specification.
WebSocketNamespaceHandler - Class in org.springframework.integration.websocket.config
 
WebSocketNamespaceHandler() - Constructor for class org.springframework.integration.websocket.config.WebSocketNamespaceHandler
 
WebSocketOutboundMessageHandler - Class in org.springframework.integration.websocket.outbound
 
WebSocketOutboundMessageHandler(IntegrationWebSocketContainer) - Constructor for class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
WebSocketOutboundMessageHandler(IntegrationWebSocketContainer, SubProtocolHandlerRegistry) - Constructor for class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
WebSocketOutboundMessageHandlerParser - Class in org.springframework.integration.websocket.config
The AbstractOutboundChannelAdapterParser implementation for the <websocket:outbound-channel-adapter/> element.
WebSocketOutboundMessageHandlerParser() - Constructor for class org.springframework.integration.websocket.config.WebSocketOutboundMessageHandlerParser
 
WebSocketStompSessionManager - Class in org.springframework.integration.stomp
WebSocketStompSessionManager(WebSocketStompClient, String, Object...) - Constructor for class org.springframework.integration.stomp.WebSocketStompSessionManager
 
whileLocked() - Method in class org.springframework.integration.util.WhileLockedProcessor
Override this method to provide the behavior that needs to be executed while under the lock.
WhileLockedProcessor - Class in org.springframework.integration.util
A simple strategy callback class that allows you to provide a code that needs to be executed under Lock provided by LockRegistry A typical usage would be to provide implementation of WhileLockedProcessor.whileLocked() method and then call WhileLockedProcessor.doWhileLocked()
WhileLockedProcessor(LockRegistry, Object) - Constructor for class org.springframework.integration.util.WhileLockedProcessor
 
Will(String, byte[], int, boolean) - Constructor for class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
willAddHeaders(Message<?>) - Method in class org.springframework.integration.file.splitter.FileSplitter
 
willAddHeaders(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Return true if the subclass needs to add headers in the resulting splits.
WireTap - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that publishes a copy of the intercepted message to a secondary target while still sending the original message to the main channel.
WireTap(MessageChannel) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with no MessageSelector.
WireTap(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with the provided MessageSelector.
WireTap(String) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap based on the MessageChannel name and with no MessageSelector.
WireTap(String, MessageSelector) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with the provided MessageSelector.
wireTap(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(IntegrationFlow, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(String, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(MessageChannel, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(WireTapSpec) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current BaseIntegrationFlowDefinition.currentMessageChannel.
wireTap(String) - Method in class org.springframework.integration.dsl.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
wireTap(MessageChannel) - Method in class org.springframework.integration.dsl.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
wireTap(WireTapSpec) - Method in class org.springframework.integration.dsl.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
WireTapParser - Class in org.springframework.integration.config.xml
Parser for the <wire-tap> element.
WireTapParser() - Constructor for class org.springframework.integration.config.xml.WireTapParser
 
WireTapSpec - Class in org.springframework.integration.dsl
The IntegrationComponentSpec implementation for the WireTap component.
WireTapSpec(MessageChannel) - Constructor for class org.springframework.integration.dsl.WireTapSpec
 
WireTapSpec(String) - Constructor for class org.springframework.integration.dsl.WireTapSpec
 
withPayload(T) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
 
withPayload(T) - Static method in class org.springframework.integration.support.MessageBuilder
Create a builder for a new Message instance with the provided payload.
withPayload(T) - Method in interface org.springframework.integration.support.MessageBuilderFactory
 
withPayload(T) - Static method in class org.springframework.integration.support.MutableMessageBuilder
Create a builder for a new Message instance with the provided payload.
withPayload(T, boolean) - Static method in class org.springframework.integration.support.MutableMessageBuilder
Create a builder for a new Message instance with the provided payload.
withPayload(T) - Method in class org.springframework.integration.support.MutableMessageBuilderFactory
 
withReturnType(Class<?>) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
withReturnType(Class<?>) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
withRoot(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
withRoot(Object) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
withSockJs(ServerWebSocketContainer.SockJsServiceOptions...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
workingDirExpression(String) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
Specify a SpEL Expression to evaluate FTP client working directory against request message.
workingDirExpression(Expression) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
Specify a SpEL Expression to evaluate FTP client working directory against request message.
workingDirFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
Specify a Function to evaluate FTP client working directory against request message.
wrap(JsonNode) - Static method in class org.springframework.integration.json.JsonPropertyAccessor
 
wrapConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
wrapInDeliveryExceptionIfNecessary(Message<?>, Supplier<String>, Throwable) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
If the exception is not a MessagingException or does not have a failedMessage, wrap it in a new MessageDeliveryException with the message.
wrapInHandlingExceptionIfNecessary(Message<?>, Supplier<String>, Throwable) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
If the exception is not a MessagingException or does not have a failedMessage, wrap it in a new MessageHandlingException with the message.
write(Kryo, Output, File) - Method in class org.springframework.integration.codec.kryo.FileSerializer
 
write(InputStream, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
write(InputStream, String) - Method in interface org.springframework.integration.file.remote.session.Session
 
write(InputStream, String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
write(Message<T>, NamedComponent) - Static method in class org.springframework.integration.history.MessageHistory
 
write(Message<T>, NamedComponent, MessageBuilderFactory) - Static method in class org.springframework.integration.history.MessageHistory
 
write(MultiValueMap<String, ?>, MediaType, HttpOutputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
write(EvaluationContext, Object, String, Object) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
write(InputStream, String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
write(String) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
writeHeader(OutputStream, int) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Write the header, according to the header format.
writeInternal(Serializable, HttpOutputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
written(ServerSession, String, FileHandle, long, byte[], int, int, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
Ws - Class in org.springframework.integration.ws.dsl
Factory class for web service components.
WsIntegrationConfigurationInitializer - Class in org.springframework.integration.ws.config
The IntegrationConfigurationInitializer implementation for the WebService module.
WsIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.ws.config.WsIntegrationConfigurationInitializer
 
WsNamespaceHandler - Class in org.springframework.integration.ws.config
 
WsNamespaceHandler() - Constructor for class org.springframework.integration.ws.config.WsNamespaceHandler
 

X

XmlPayloadConverter - Interface in org.springframework.integration.xml
Converter for creating XML Document, Node or Source instances from other types (e.g.
XmlPayloadValidatingFilterParser - Class in org.springframework.integration.xml.config
 
XmlPayloadValidatingFilterParser() - Constructor for class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
 
XmlValidatingMessageSelector - Class in org.springframework.integration.xml.selector
 
XmlValidatingMessageSelector(Resource, XmlValidatingMessageSelector.SchemaType) - Constructor for class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
Creates a selector with a default XmlValidator.
XmlValidatingMessageSelector(XmlValidator) - Constructor for class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
XmlValidatingMessageSelector(Resource, String) - Constructor for class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
XmlValidatingMessageSelector.SchemaType - Enum in org.springframework.integration.xml.selector
 
XMPP_CONNECTION_BEAN_NAME - Static variable in class org.springframework.integration.xmpp.config.XmppNamespaceHandler
 
XMPP_CONNECTION_BEAN_NAME - Static variable in class org.springframework.integration.xmpp.core.XmppContextUtils
 
XmppConnectionFactoryBean - Class in org.springframework.integration.xmpp.config
This class configures an XMPPTCPConnection object.
XmppConnectionFactoryBean() - Constructor for class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
XmppConnectionParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:xmpp-connection' element
XmppConnectionParser() - Constructor for class org.springframework.integration.xmpp.config.XmppConnectionParser
 
XmppContextUtils - Class in org.springframework.integration.xmpp.core
 
XmppHeaderEnricherParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:header-enricher' element
XmppHeaderEnricherParser() - Constructor for class org.springframework.integration.xmpp.config.XmppHeaderEnricherParser
 
XmppHeaderMapper - Interface in org.springframework.integration.xmpp.support
A convenience interface that extends RequestReplyHeaderMapper but parameterized with the Smack API Message.
XmppHeaders - Class in org.springframework.integration.xmpp
Used as keys for Message objects that handle XMPP events.
XmppNamespaceHandler - Class in org.springframework.integration.xmpp.config
This class parses the schema for XMPP support.
XmppNamespaceHandler() - Constructor for class org.springframework.integration.xmpp.config.XmppNamespaceHandler
 
XPathEvaluationType - Enum in org.springframework.integration.xml.xpath
Enumeration of different types of XPath evaluation used to indicate the type of evaluation that should be carried out using a provided XPath expression.
XPathExpressionEvaluatingHeaderValueMessageProcessor - Class in org.springframework.integration.xml.transformer.support
 
XPathExpressionEvaluatingHeaderValueMessageProcessor(String) - Constructor for class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
XPathExpressionEvaluatingHeaderValueMessageProcessor(String, XmlPayloadConverter) - Constructor for class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
Construct an instance based on the provided xpath expression and XmlPayloadConverter.
XPathExpressionEvaluatingHeaderValueMessageProcessor(XPathExpression) - Constructor for class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
 
XPathExpressionEvaluatingHeaderValueMessageProcessor(XPathExpression, XmlPayloadConverter) - Constructor for class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
Construct an instance based on the provided xpath expression and XmlPayloadConverter.
XPathExpressionParser - Class in org.springframework.integration.xml.config
Parser for the <xpath-expression> element.
XPathExpressionParser() - Constructor for class org.springframework.integration.xml.config.XPathExpressionParser
 
XPathFilterParser - Class in org.springframework.integration.xml.config
Parser for the <xpath-filter> element.
XPathFilterParser() - Constructor for class org.springframework.integration.xml.config.XPathFilterParser
 
XPathHeaderEnricher - Class in org.springframework.integration.xml.transformer
Transformer implementation that evaluates XPath expressions against the message payload and inserts the result of the evaluation into a message header.
XPathHeaderEnricher(Map<String, XPathExpressionEvaluatingHeaderValueMessageProcessor>) - Constructor for class org.springframework.integration.xml.transformer.XPathHeaderEnricher
Create an instance of XPathHeaderEnricher using a map with header names as keys and XPathExpressionValueHolders to evaluate the values.
XPathHeaderEnricherParser - Class in org.springframework.integration.xml.config
Parser for <xpath-header-enricher> elements.
XPathHeaderEnricherParser() - Constructor for class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
XPathMessageSplitter - Class in org.springframework.integration.xml.splitter
Message Splitter that uses an XPathExpression to split a Document, File or String payload into a NodeList.
XPathMessageSplitter(String) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
XPathMessageSplitter(String, TransformerFactory) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
Construct an instance based on the provided xpath expression and TransformerFactory.
XPathMessageSplitter(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
XPathMessageSplitter(String, Map<String, String>, TransformerFactory) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
Construct an instance based on the provided xpath expression, namespaces and TransformerFactory.
XPathMessageSplitter(XPathExpression) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
XPathMessageSplitter(XPathExpression, TransformerFactory) - Constructor for class org.springframework.integration.xml.splitter.XPathMessageSplitter
Construct an instance based on the provided xpath expression and TransformerFactory.
XPathMessageSplitterParser - Class in org.springframework.integration.xml.config
 
XPathMessageSplitterParser() - Constructor for class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
XPathRouter - Class in org.springframework.integration.xml.router
Message Router that uses XPathExpression evaluation to determine channel names.
XPathRouter(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.router.XPathRouter
Create a router that uses an XPath expression.
XPathRouter(String, String, String) - Constructor for class org.springframework.integration.xml.router.XPathRouter
Create a router uses an XPath expression with one namespace.
XPathRouter(String) - Constructor for class org.springframework.integration.xml.router.XPathRouter
Create a router that uses an XPath expression with no namespaces.
XPathRouter(XPathExpression) - Constructor for class org.springframework.integration.xml.router.XPathRouter
Create a router that uses the provided XPath expression.
XPathRouterParser - Class in org.springframework.integration.xml.config
Parser for the <xpath-router/> element.
XPathRouterParser() - Constructor for class org.springframework.integration.xml.config.XPathRouterParser
 
XPathTransformer - Class in org.springframework.integration.xml.transformer
Transformer implementation that evaluates an XPath expression against the inbound Message payload and returns a Message whose payload is the result of that evaluation.
XPathTransformer(String) - Constructor for class org.springframework.integration.xml.transformer.XPathTransformer
Create an XPathTransformer that will create an XPath expression from the given String to be evaluated against converted inbound Message payloads.
XPathTransformer(XPathExpression) - Constructor for class org.springframework.integration.xml.transformer.XPathTransformer
Create an XPathTransformer that will evaluate the given XPathExpression against converted inbound Message payloads.
XPathTransformerParser - Class in org.springframework.integration.xml.config
Parser for the 'xpath-transformer' element.
XPathTransformerParser() - Constructor for class org.springframework.integration.xml.config.XPathTransformerParser
 
XPathUtils - Class in org.springframework.integration.xml.xpath
Utility class for 'xpath' support.
XsltPayloadTransformer - Class in org.springframework.integration.xml.transformer
Thread safe XSLT transformer implementation which returns a transformed Source, Document, or String.
XsltPayloadTransformer(Templates) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformer(Templates, ResultTransformer) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformer(Resource) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformer(Resource, ResultTransformer) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformer(Resource, String) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformer(Resource, ResultTransformer, String) - Constructor for class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
XsltPayloadTransformerParser - Class in org.springframework.integration.xml.config
 
XsltPayloadTransformerParser() - Constructor for class org.springframework.integration.xml.config.XsltPayloadTransformerParser
 

Y

yield() - Method in interface org.springframework.integration.leader.Context
Causes the Candidate this context was passed to to relinquish leadership.
yieldLeadership() - Method in class org.springframework.integration.leader.DefaultCandidate
Voluntarily yield leadership if held.

Z

ZeroMq - Class in org.springframework.integration.zeromq.dsl
Factory class for ZeroMq components DSL.
ZeroMqChannel - Class in org.springframework.integration.zeromq.channel
The SubscribableChannel implementation over ZeroMQ sockets.
ZeroMqChannel(ZContext) - Constructor for class org.springframework.integration.zeromq.channel.ZeroMqChannel
Create a channel instance based on the provided ZContext with push/pull communication model.
ZeroMqChannel(ZContext, boolean) - Constructor for class org.springframework.integration.zeromq.channel.ZeroMqChannel
Create a channel instance based on the provided ZContext and provided communication model.
zeroMqChannel(ZContext) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
Create an instance of ZeroMqChannelSpec based on the provided ZContext.
ZeroMqChannelSpec - Class in org.springframework.integration.zeromq.dsl
ZeroMqChannelSpec(ZContext, boolean) - Constructor for class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
 
ZeroMqHeaders - Class in org.springframework.integration.zeromq
The message headers constants to repsent ZeroMq message attributes.
ZeroMqMessageHandler - Class in org.springframework.integration.zeromq.outbound
The AbstractReactiveMessageHandler implementation for publishing messages over ZeroMq socket.
ZeroMqMessageHandler(ZContext, String) - Constructor for class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Create an instance based on the provided ZContext and connection string.
ZeroMqMessageHandler(ZContext, String, SocketType) - Constructor for class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Create an instance based on the provided ZContext, connection string and SocketType.
ZeroMqMessageHandlerSpec - Class in org.springframework.integration.zeromq.dsl
ZeroMqMessageHandlerSpec(ZContext, String) - Constructor for class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Create an instance based on the provided ZContext and connection string.
ZeroMqMessageHandlerSpec(ZContext, String, SocketType) - Constructor for class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
Create an instance based on the provided ZContext, connection string and SocketType.
ZeroMqMessageProducer - Class in org.springframework.integration.zeromq.inbound
A MessageProducerSupport implementation for consuming messages from ZeroMq socket.
ZeroMqMessageProducer(ZContext) - Constructor for class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
ZeroMqMessageProducer(ZContext, SocketType) - Constructor for class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
ZeroMqMessageProducerSpec - Class in org.springframework.integration.zeromq.dsl
 
ZeroMqMessageProducerSpec(ZContext) - Constructor for class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
 
ZeroMqMessageProducerSpec(ZContext, SocketType) - Constructor for class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
 
zeroMqProxy(ZeroMqProxy) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
Specify a reference to a ZeroMqProxy instance in the same application to rely on its ports configuration and make a natural lifecycle dependency without guessing when the proxy is started.
ZeroMqProxy - Class in org.springframework.integration.zeromq
This class encapsulates the logic to configure and manage a ZeroMQ proxy.
ZeroMqProxy(ZContext) - Constructor for class org.springframework.integration.zeromq.ZeroMqProxy
Create a ZeroMqProxy instance based on the provided ZContext and ZeroMqProxy.Type.PULL_PUSH as default mode.
ZeroMqProxy(ZContext, ZeroMqProxy.Type) - Constructor for class org.springframework.integration.zeromq.ZeroMqProxy
Create a ZeroMqProxy instance based on the provided ZContext and ZeroMqProxy.Type.
ZeroMqProxy.Type - Enum in org.springframework.integration.zeromq
 
ZookeeperLockRegistry - Class in org.springframework.integration.zookeeper.lock
ExpirableLockRegistry implementation using Zookeeper, or more specifically, Curator InterProcessMutex.
ZookeeperLockRegistry(CuratorFramework) - Constructor for class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Construct a lock registry using the default ZookeeperLockRegistry.KeyToPathStrategy which simple appends the key to '/SpringIntegration-LockRegistry/'.
ZookeeperLockRegistry(CuratorFramework, String) - Constructor for class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Construct a lock registry using the default ZookeeperLockRegistry.KeyToPathStrategy which simple appends the key to '<root>/'.
ZookeeperLockRegistry(CuratorFramework, ZookeeperLockRegistry.KeyToPathStrategy) - Constructor for class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Construct a lock registry using the supplied ZookeeperLockRegistry.KeyToPathStrategy.
ZookeeperLockRegistry.KeyToPathStrategy - Interface in org.springframework.integration.zookeeper.lock
Strategy to convert a lock key (e.g.
ZookeeperMetadataStore - Class in org.springframework.integration.zookeeper.metadata
Zookeeper-based ListenableMetadataStore based on a Zookeeper node.
ZookeeperMetadataStore(CuratorFramework) - Constructor for class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
ZookeeperMetadataStoreException - Exception in org.springframework.integration.zookeeper.metadata
 
ZookeeperMetadataStoreException(String) - Constructor for exception org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStoreException
 
ZookeeperMetadataStoreException(String, Throwable) - Constructor for exception org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStoreException
 
ZookeeperNamespaceHandler - Class in org.springframework.integration.zookeeper.config.xml
 
ZookeeperNamespaceHandler() - Constructor for class org.springframework.integration.zookeeper.config.xml.ZookeeperNamespaceHandler
 
ZSET_INCREMENT_SCORE - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
ZSET_SCORE - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 

_

_this() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
_this() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
_this() - Method in class org.springframework.integration.support.MapBuilder
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links
Spring Integration