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 BasicMessageGroupStore 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(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
AbstractConfigurableMongoDbMessageStore(MongoDbFactory, 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
 
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
 
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
 
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
 
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 all TCP/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
 
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
 
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.
AbstractMessageChannelMetrics - Class in org.springframework.integration.support.management
Abstract base class for channel metrics implementations.
AbstractMessageChannelMetrics(String) - Constructor for class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
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 that provides basic validation and error handling capabilities.
AbstractMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageHandler
 
AbstractMessageHandlerMetrics - Class in org.springframework.integration.support.management
Abstract base class for handler metrics implementations.
AbstractMessageHandlerMetrics(String) - Constructor for class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
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
 
AbstractMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractMessageSource
 
AbstractMessageSourceAdvice - Class in org.springframework.integration.aop
Advice for a MessageSource.receive() method to decide whether a poll should be ignored and/or take action after the receive.
AbstractMessageSourceAdvice() - Constructor for class org.springframework.integration.aop.AbstractMessageSourceAdvice
 
AbstractMessageSplitter - Class in org.springframework.integration.splitter
Base class for Message-splitting handlers.
AbstractMessageSplitter() - Constructor for class org.springframework.integration.splitter.AbstractMessageSplitter
 
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
 
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<AbstractFileInfo<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.
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
 
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
 
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
 
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
 
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(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(File) - Method in class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
 
accept(File) - Method in class org.springframework.integration.file.locking.AbstractFileLockerFilter
 
accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
ACCEPT - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
ACCEPT_CHARSET - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
ACCEPT_ENCODING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
ACCEPT_LANGUAGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
ACCEPT_RANGES - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
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.
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.support.management.DefaultMessageHandlerMetrics
 
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
 
addAttribute(String, Object) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
Adds attribute to this ResourceHolder instance
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
 
addConstuctorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
addCustomHeaders(TcpConnection, AbstractIntegrationMessageBuilder<?>) - 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.
addElementToHeaderMapping(String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
addElementToHeaderMapping(String, String, Class<?>) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
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
 
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 interface org.springframework.integration.channel.ChannelInterceptorAware
And a ChannelInterceptor to the target implementation.
addInterceptor(int, ChannelInterceptor) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
And a ChannelInterceptor to the target implementation for the specific index.
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
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 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(ChannelInterceptorAware, 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.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.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 headers 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.
addPatternMapping(Pattern, ChannelAccessPolicy) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
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, 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
Add a session factory.
addStandardHeaders(TcpConnection, AbstractIntegrationMessageBuilder<?>) - 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.
addWhiteListPatterns(String...) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addWhiteListPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addWhiteListPatterns(String...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
Add patterns for packages/classes that are allowed to be deserialized.
addWhiteListPatterns(String...) - Method in class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
Add patterns for packages/classes that are allowed to be deserialized.
addWhiteListPatterns(String...) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Add package/class patterns to the white list.
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
 
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
 
afterError() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
afterError() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
End a handle event
afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
 
afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
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.endpoint.MethodInvokingMessageSource
 
afterPropertiesSet() - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
afterPropertiesSet() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
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.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
afterPropertiesSet() - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
Deprecated.
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.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
Deprecated.
without no-op, in favor of just constructor initialization
afterPropertiesSet() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
Deprecated.
without no-op, in favor of just constructor initialization
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
 
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Deprecated.
since 4.3.9 in favor of initialization and assertions in constructors.
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
 
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.resource.ResourceRetrievingMessageSource
 
afterPropertiesSet() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
afterPropertiesSet() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
afterPropertiesSet() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
afterPropertiesSet() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
Subclasses can take actions based on the result of the poll; e.g.
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
 
afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
 
afterReceive() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
afterReceive() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
afterReceiveCompletion(Message<?>, MessageChannel, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
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
 
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
 
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
 
afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
End a send event.
afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
 
afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
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.HttpRequestHandlingEndpointSupport
 
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.JmsMessageDrivenEndpoint
 
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.endpoint.MessageProducerSupport
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
afterTest() - Method in class org.springframework.integration.test.support.LogAdjustingTestSupport
 
AGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
AggregatingChannelMetricsContext(long, long) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext
 
AggregatingHandlerMetricsContext(long, long) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext
 
AggregatingMessageChannelMetrics - Class in org.springframework.integration.support.management
An implementation of MessageChannelMetrics that aggregates the total response time over a sample, to avoid fetching the system time twice for every message.
AggregatingMessageChannelMetrics() - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
 
AggregatingMessageChannelMetrics(String, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
Construct an instance with default metrics with window=10, period=1 second, lapsePeriod=1 minute.
AggregatingMessageChannelMetrics(String, ExponentialMovingAverage, ExponentialMovingAverageRate, ExponentialMovingAverageRatio, ExponentialMovingAverageRate, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
Construct an instance with the supplied metrics.
AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext - Class in org.springframework.integration.support.management
 
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
 
AggregatingMessageHandlerMetrics - Class in org.springframework.integration.support.management
An implementation of MessageHandlerMetrics that aggregates the total response time over a sample, to avoid fetching the system time twice for every message.
AggregatingMessageHandlerMetrics() - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
 
AggregatingMessageHandlerMetrics(String, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
Construct an instance with the default moving average window (10).
AggregatingMessageHandlerMetrics(String, ExponentialMovingAverage, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
Construct an instance with the supplied ExponentialMovingAverage calculating the duration of processing by the message handler (and any downstream synchronous endpoints).
AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext - Class in org.springframework.integration.support.management
 
AggregatingMetricsFactory - Class in org.springframework.integration.support.management
Implementation that returns aggregating metrics.
AggregatingMetricsFactory(int) - Constructor for class org.springframework.integration.support.management.AggregatingMetricsFactory
 
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
 
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.
ALLOW - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
AMQP_RAW_MESSAGE - Static variable in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
Header name/retry context variable for the raw received message.
AmqpChannelFactoryBean - Class in org.springframework.integration.amqp.config
If point-to-point, we send to the default exchange with the routing key equal to "[beanName]" and we declare that same Queue and register a listener if message-driven or poll explicitly otherwise.
AmqpChannelFactoryBean() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
AmqpChannelFactoryBean(boolean) - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
AmqpChannelParser - Class in org.springframework.integration.amqp.config
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration AMQP namespace.
AmqpChannelParser() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelParser
 
AmqpHeaderMapper - Interface in org.springframework.integration.amqp.support
A convenience interface that extends HeaderMapper but 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.Listener - Class in org.springframework.integration.amqp.inbound
 
AmqpInboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
Parser for the AMQP 'inbound-channel-adapter' element.
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
 
AmqpInboundGatewayParser - Class in org.springframework.integration.amqp.config
Parser for the AMQP 'inbound-gateway' element.
AmqpMessageHeaderErrorMessageStrategy - Class in org.springframework.integration.amqp.support
An ErrorMessageStrategy extension that adds the raw AMQP message as a header to the org.springframework.integration.message.EnhancedErrorMessage.
AmqpMessageHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
 
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
 
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
 
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
 
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.
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
 
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
 
append(double) - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
Add a new measurement to the series.
applicationContext - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
An inbound Channel Adapter that implements ApplicationListener 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(Statement, Description) - Method in class org.springframework.integration.test.rule.Log4jClassLevelAdjuster
 
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.integration.test.rule.Log4jLevelAdjuster
 
apply(Statement, Description) - Method in class org.springframework.integration.test.support.LongRunningIntegrationTest
 
apply(T) - Method in interface org.springframework.integration.util.Function
Execute the logic of the action, accepting the given parameter.
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.
applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
applySystemFileSeparator(String) - Static method in class org.springframework.integration.test.util.TestUtils
Update file path by replacing any '/' with the system's file separator.
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
 
assertions - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
assertReceived(String) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
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
 
AsyncMessagingOperations - Interface in org.springframework.integration.core
 
AsyncMessagingTemplate - Class in org.springframework.integration.core
 
AsyncMessagingTemplate() - Constructor for class org.springframework.integration.core.AsyncMessagingTemplate
 
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
 
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
 
AUTHORIZATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
autoCreateDirectChannel(String, BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
availablePermits() - Method in class org.springframework.integration.util.UpperBound
 
await() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 

B

BACKLOG - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
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.
BarrierParser - Class in org.springframework.integration.config.xml
Parser for <int:barrier/>.
BarrierParser() - Constructor for class org.springframework.integration.config.xml.BarrierParser
 
BASE_PACKAGE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
BasicMessageGroupStore - Interface in org.springframework.integration.store
Defines a minimal message group store with basic capabilities.
BCC - Static variable in class org.springframework.integration.mail.MailHeaders
 
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
beanClassLoader - Variable in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
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
 
beanFactory - Variable in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
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
 
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
 
beforeHandle(Message<?>, MessageChannel, MessageHandler) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
beforeHandle() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
Begin a handle event.
beforeHandle() - Method in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
 
beforeHandle() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
Subclasses can decide whether to proceed with this poll.
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
 
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
 
beforeSend() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
Begin a send event.
beforeSend() - Method in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
 
beforeSend() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
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.HttpRequestHandlingEndpointSupport
 
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.JmsMessageDrivenEndpoint
 
beforeShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
beforeTest() - Method in class org.springframework.integration.test.support.LogAdjustingTestSupport
 
BODY - Static variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
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.
BoonJsonObjectMapper - Class in org.springframework.integration.support.json
The Boon (@link https://github.com/RichardHightower/boon) JsonObjectMapper implementation.
BoonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.BoonJsonObjectMapper
 
BoonJsonObjectMapper(JsonParserFactory, JsonSerializerFactory) - Constructor for class org.springframework.integration.support.json.BoonJsonObjectMapper
 
bounded() - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
 
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
 
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
 
bufferSize - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
build() - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapFinalBuilder
 
build() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
build() - Method in class org.springframework.integration.support.MessageBuilder
 
build() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
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.redis.config.RedisChannelParser
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
 
buildErrorMessage(Message<?>, RuntimeException) - 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.support.DefaultErrorMessageStrategy
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in interface org.springframework.integration.support.ErrorMessageStrategy
Build the error message.
buildKey(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
The default key is the AbstractPersistentAcceptOnceFileListFilter.prefix plus the full filename.
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
 
buildReplyMessage(MessageConverter, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
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
 
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
 
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
Constructs the serializer using ByteArrayLengthHeaderSerializer.HEADER_SIZE_INT
ByteArrayLengthHeaderSerializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Constructs 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
 
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

CACHE_CONTROL - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
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
 
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.
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 messages (a collection) in the group 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
 
CC - Static variable in class org.springframework.integration.mail.MailHeaders
 
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
 
ChainParser - Class in org.springframework.integration.config.xml
Parser for the <chain> element.
ChainParser() - Constructor for class org.springframework.integration.config.xml.ChainParser
 
CHANNEL_INITIALIZER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
Interface to encapsulate ConfigAttributes for secured channel send and receive operations.
ChannelInterceptorAware - Interface in org.springframework.integration.channel
A marker interface providing the ability to configure ChannelInterceptors on MessageChannel implementations.
ChannelInterceptorList(Log) - 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
 
channelMappings - Variable in class org.springframework.integration.router.AbstractMappingMessageRouter
 
ChannelMessageStore - Interface in org.springframework.integration.store
A marker interface that indicates this message store has optimizations for use in a QueueChannel.
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.
channels - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
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).
CharacterStreamReadingMessageSource - Class in org.springframework.integration.stream
A pollable source for Readers.
CharacterStreamReadingMessageSource(Reader) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
CharacterStreamReadingMessageSource(Reader, int) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
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
 
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
 
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
 
checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
Creates a default task executor if none was supplied.
checkWhiteList(Class<?>) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
 
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.
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.
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
 
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> - Class in org.springframework.integration.file.remote
RemoteFileTemplate callback with the underlying client instance providing access to lower level methods where no result is returned.
ClientCallbackWithoutResult() - Constructor for class org.springframework.integration.file.remote.ClientCallbackWithoutResult
 
clientMode - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
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
 
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.
close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
 
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 class org.springframework.integration.util.FunctionIterator
 
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().
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
 
Codec - Interface in org.springframework.integration.codec
Interface for classes that perform both encode (serialize) and decode (deserialize) on multiple classes.
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_NAME - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
 
CollectionFilter<T> - Interface in org.springframework.integration.util
Base strategy for filtering out a subset of a Collection of elements.
collectionName - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
command - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
COMMAND - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
CommonSocketOptions - Interface in org.springframework.integration.ip
 
compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.MessageSequenceComparator
 
compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.SequenceNumberComparator
If both messages have a sequence number then compare that, otherwise if one has a sequence number and the other doesn't then the numbered message comes first, or finally of neither has a sequence number then they are equal in rank.
compareTo(FileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
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) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
completeGroup(Message<?>, Object, MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
completeGroup(Object) - Method in class org.springframework.integration.jdbc.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, Class<?>) - Constructor for class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
 
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.support.management.graph
Represents a composite message handler.
CompositeMessageHandlerNode(int, String, MessageHandler, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode
 
CompositeMessageHandlerNode.InnerHandler - Class in org.springframework.integration.support.management.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
An AbstractMessageSourceAdvice 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
 
ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
Supports atomic updates to values in the store.
config - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
ConfigurableMetrics - Interface in org.springframework.integration.support.management
Marker interface for metrics.
ConfigurableMetricsAware<M extends ConfigurableMetrics> - Interface in org.springframework.integration.support.management
Classes implementing this interface can accept a ConfigurableMetrics.
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(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDbFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
ConfigurableMongoDbMessageStore(MongoDbFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
configure(RmiProxyFactoryBean) - Method in interface org.springframework.integration.rmi.RmiOutboundGateway.RmiProxyFactoryBeanConfigurer
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
 
configureAndSetAdviceChainIfPresent(Element, Element, 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
 
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
 
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.
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
 
configureMappingRouter(AbstractMappingMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
 
configureMetrics(AbstractMessageChannelMetrics) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
configureMetrics(AbstractMessageChannelMetrics) - Method in class org.springframework.integration.channel.NullChannel
 
configureMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
configureMetrics(M) - Method in interface org.springframework.integration.support.management.ConfigurableMetricsAware
 
configureMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
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
 
configureSplitter(AbstractMessageSplitter) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
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.
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
 
connect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
connect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
 
connectIfNeeded() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Deprecated.
subclasses should check the connection in AbstractMqttMessageHandler.publish(String, Object, Message).
CONNECTION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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 - Interface in org.springframework.integration.ip.tcp.connection
A factory used to create TcpConnection objects.
connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
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
 
constructType(Type) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
constructType(Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
 
ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
ConsumerStopAction - Enum in org.springframework.integration.mqtt.core
Action to take regarding subscrptions when consumer stops.
contains(Object) - Method in class org.springframework.integration.history.MessageHistory
 
containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
containsElementIgnoreCase(String[], String) - 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_DISPOSITION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_ENCODING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_LANGUAGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_LENGTH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_LOCATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_MD5 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_RANGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
CONTENT_TYPE - 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
 
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
 
ControlBusMethodFilter - Class in org.springframework.integration.expression
SpEL MethodFilter to restrict method invocations to: 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
 
controlEncoding - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
conversionService - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
convert(MBeanServerConnection, ObjectInstance) - Method in class org.springframework.integration.jmx.DefaultMBeanObjectConverter
 
convert(MBeanServerConnection, ObjectInstance) - Method in interface org.springframework.integration.jmx.MBeanObjectConverter
 
convert(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
 
convert(byte[]) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
 
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.transformer.PayloadTypeConvertingTransformer
 
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
 
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.
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
 
COOKIE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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(MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
CorrelatingMessageBarrier() - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
CORRELATION_ID - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
CORRELATION_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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.
CorrelationStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a CorrelationStrategy.
CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
CorrelationStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
CorrelationStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
CqEventType - Enum in org.springframework.integration.gemfire.inbound
Enumeration of GemFire Continuous Query Event Types
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 interface org.springframework.integration.transaction.TransactionSynchronizationFactory
 
createChannelMetrics(String) - Method in class org.springframework.integration.support.management.AggregatingMetricsFactory
 
createChannelMetrics(String) - Method in class org.springframework.integration.support.management.DefaultMetricsFactory
 
createChannelMetrics(String) - Method in interface org.springframework.integration.support.management.MetricsFactory
Factory method to create an AbstractMessageChannelMetrics.
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.
CREATED_DATE - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
CREATED_DATE_KEY - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
The name of the message header that stores a timestamp for the time the message was inserted.
CREATED_DATE_KEY - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
The name of the message header that stores a timestamp for the time the message was inserted.
CREATED_DATE_KEY - Static variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
The name of the message header that stores a timestamp for the time the message was inserted.
CREATED_DATE_KEY - Static variable in class org.springframework.integration.mongodb.store.MongoDbMessageStore
The name of the message header that stores a timestamp for the time the message was inserted.
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
 
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.HttpRequestHandlingEndpointSupport
 
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
 
createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
createHandlerMetrics(String) - Method in class org.springframework.integration.support.management.AggregatingMetricsFactory
 
createHandlerMetrics(String) - Method in class org.springframework.integration.support.management.DefaultMetricsFactory
 
createHandlerMetrics(String) - Method in interface org.springframework.integration.support.management.MetricsFactory
Factory method to create an AbstractMessageHandlerMetrics.
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.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.jpa.outbound.JpaOutboundGatewayFactoryBean
 
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
 
createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
createJsonParser(String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
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(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(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
 
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
 
createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
 
createWriter(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Create a buffered writer for the file, for String payloads.
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
 

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
 
DATE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
DATE_FORMATS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
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(Node, BeanDefinitionHolder, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
decorate(MessageHandlingRunnable) - Method in interface org.springframework.integration.dispatcher.MessageHandlingTaskDecorator
 
decorateMessage(Message<?>) - Method in interface org.springframework.integration.support.MessageDecorator
 
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
 
DEFAULT_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
DEFAULT_FILE_REGISTRATION_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_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_MOVING_AVERAGE_WINDOW - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
DEFAULT_MUTABLE_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
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_PORT - Static variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
DEFAULT_PORT_RANGE_MAX - Static variable in class org.springframework.integration.test.util.SocketUtils
 
DEFAULT_PORT_RANGE_MIN - Static variable in class org.springframework.integration.test.util.SocketUtils
 
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_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.JdbcMessageStore
Default value for the table prefix property.
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.store.JdbcChannelMessageStore
Default value for the table prefix property.
DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
Default threshold is effectively infinite.
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.
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() - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
Deprecated.
- use DefaultAmqpHeaderMapper.inboundMapper() and DefaultAmqpHeaderMapper.outboundMapper() depending on the context in which the mapper is to be used.
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.
DefaultChannelMetricsContext(long) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics.DefaultChannelMetricsContext
 
DefaultDatatypeChannelMessageConverter - Class in org.springframework.integration.support.converter
Default message converter for datatype channels.
DefaultDatatypeChannelMessageConverter() - Constructor for class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
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
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
 
DefaultFileNameGenerator - Class in org.springframework.integration.file
Default implementation of the filename generator strategy.
DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
 
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
 
DefaultHandlerMetricsContext(long) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext
 
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
 
DefaultMessageChannelMetrics - Class in org.springframework.integration.support.management
Default implementation; use the full constructor to customize the moving averages.
DefaultMessageChannelMetrics() - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
DefaultMessageChannelMetrics(String) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
Construct an instance with default metrics with window=10, period=1 second, lapsePeriod=1 minute.
DefaultMessageChannelMetrics(String, ExponentialMovingAverage, ExponentialMovingAverageRate, ExponentialMovingAverageRatio, ExponentialMovingAverageRate) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
Construct an instance with the supplied metrics.
DefaultMessageChannelMetrics.DefaultChannelMetricsContext - Class in org.springframework.integration.support.management
 
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
 
DefaultMessageHandlerMetrics - Class in org.springframework.integration.support.management
Default implementation; use the full constructor to customize the moving averages.
DefaultMessageHandlerMetrics() - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
DefaultMessageHandlerMetrics(String) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
Construct an instance with the default moving average window (10).
DefaultMessageHandlerMetrics(String, ExponentialMovingAverage) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
Construct an instance with the supplied ExponentialMovingAverage calculating the duration of processing by the message handler (and any downstream synchronous endpoints).
DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext - Class in org.springframework.integration.support.management
 
DefaultMessageSplitter - Class in org.springframework.integration.splitter
The default Message Splitter implementation.
DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
 
DefaultMetricsFactory - Class in org.springframework.integration.support.management
Default implementation.
DefaultMetricsFactory() - Constructor for class org.springframework.integration.support.management.DefaultMetricsFactory
 
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
 
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.
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 ScriptExecutor
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
 
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
 
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
 
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.
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
 
DelayerParser - Class in org.springframework.integration.config.xml
Parser for the <delayer> element.
DelayerParser() - Constructor for class org.springframework.integration.config.xml.DelayerParser
 
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
 
delegate - Variable in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
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
 
deleteInBatch(Iterable<?>) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
deleteInBatch(Iterable<?>) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
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.
deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
DerbyChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
DerbyChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.EventuallyMatcher
 
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.PayloadAndHeaderMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
 
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Reads 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.WhiteListDeserializingConverter
 
deserialize(InputStream) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
DESTINATION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
destroy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
destroy() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
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.jms.JmsMessageDrivenEndpoint
 
destroy() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
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.metadata.PropertiesPersistingMetadataStore
 
destroy() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
destroy() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
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 class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
destroy() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
destroy() - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
 
destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
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
 
determinePayload(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.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
 
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.
DirectMessageReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
This class handles support for receiving DMs (direct messages) using Twitter.
DirectMessageReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.DirectMessageReceivingMessageSource
 
DirectMessageSendingMessageHandler - Class in org.springframework.integration.twitter.outbound
Simple adapter to support sending outbound direct messages ("DM"s) using Twitter.
DirectMessageSendingMessageHandler(Twitter) - Constructor for class org.springframework.integration.twitter.outbound.DirectMessageSendingMessageHandler
 
DirectoryScanner - Interface in org.springframework.integration.file
Strategy for scanning directories.
dirty() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
DiscardingMessageHandler - Interface in org.springframework.integration.handler
Classes implementing this interface are capable of discarding messages.
DiscardingMessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents an endpoint that has a discard channel.
DiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.support.management.graph.DiscardingMessageHandlerNode
 
disconnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
disconnect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
 
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
dispatch(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
 
dispatcher - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
DM_TARGET_USER_ID - Static variable in class org.springframework.integration.twitter.core.TwitterHeaders
 
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(RemoteFileTemplate<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(RemoteFileTemplate<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.Reactor2TcpStompSessionManager
 
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
 
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
 
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, HttpServletResponse) - 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
 
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.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.HttpRequestExecutingMessageHandler
 
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.jmx.OperationInvokingMessageHandler
 
doInit() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
doInit() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
doInit() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
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.twitter.outbound.TwitterSearchOutboundGateway
 
doInit() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
doInit() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
doInParser(JsonInboundMessageMapper, String) - 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 class org.springframework.integration.file.remote.SessionCallbackWithoutResult
 
doInSessionWithoutResult(Session<F>) - Method in class 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.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.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
 
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
 
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, 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.TcpConnectionEventInboundChannelAdapterParser
Deprecated.
 
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.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.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() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
 
doPoll(ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
 
doPollForMessage(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
This method executes a call to the DB to get the oldest Message in the MessageGroup Override this method if need to.
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.
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.redis.config.RedisQueueInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
doReceive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
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.AbstractMessageSource
Subclasses must implement this method.
doReceive() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
doReceive() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
doReceive() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
doReceive() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Polls from the file source.
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.resource.ResourceRetrievingMessageSource
 
doReceive() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
 
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
 
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.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.redis.channel.SubscribableRedisChannel
 
doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
doSetRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
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
Takes no action by default.
doStart() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
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.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.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.mail.ImapIdleChannelAdapter
 
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.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.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
 
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
Takes no action by default.
doStop() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
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.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.JmsMessageDrivenEndpoint
 
doStop() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Unregisters the notification listener.
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
 
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
 
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.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 class org.springframework.integration.file.remote.ClientCallbackWithoutResult
 
doWithClientWithoutResult(C) - Method in class 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
 
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
 
duration - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
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(long, TimeUnit) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
Create a trigger with the given period and time unit.

E

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 DispatcherServlet 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.
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.
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
 
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
 
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.support.management.graph
Base class for all endpoints.
EndpointNode(int, String, Object, String, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.EndpointNode
 
ENDPOINTS_NO_AUTO_STARTUP - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of AbstractEndpoint.autoStartup.
EnhancedErrorMessage - Class in org.springframework.integration.message
Deprecated.
since 4.3.10 in favor of direct ErrorMessage usage since 5.0.
EnhancedErrorMessage(Throwable, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
EnhancedErrorMessage(Throwable, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
EnhancedErrorMessage(Throwable, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
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
 
EnricherParser - Class in org.springframework.integration.config.xml
Parser for the 'enricher' element.
EnricherParser() - Constructor for class org.springframework.integration.config.xml.EnricherParser
 
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 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.support.MutableMessage
 
equals(Object) - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
equals(Object) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
equalsResult(EqualsResultMatcher.Evaluator<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 EqualsResultMatcher.Evaluator The goal is to defer the computation until the matcher needs to be actually evaluated.
EqualsResultMatcher(EqualsResultMatcher.Evaluator<U>) - Constructor for class org.springframework.integration.test.matcher.EqualsResultMatcher
 
EqualsResultMatcher.Evaluator<U> - Interface in org.springframework.integration.test.matcher
 
ERROR_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ErrorCapableCompositeMessageHandlerNode - Class in org.springframework.integration.support.management.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.support.management.graph.ErrorCapableCompositeMessageHandlerNode
 
ErrorCapableDiscardingMessageHandlerNode - Class in org.springframework.integration.support.management.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.support.management.graph.ErrorCapableDiscardingMessageHandlerNode
 
ErrorCapableEndpointNode - Class in org.springframework.integration.support.management.graph
Represents nodes that can natively handle errors.
ErrorCapableEndpointNode(int, String, Object, String, String, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableEndpointNode
 
ErrorCapableMessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents a message handler that can produce errors (pollable).
ErrorCapableMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableMessageHandlerNode
 
ErrorCapableNode - Interface in org.springframework.integration.support.management.graph
Nodes implementing this interface are capable of emitting errors.
ErrorCapableRoutingNode - Class in org.springframework.integration.support.management.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.support.management.graph.ErrorCapableRoutingNode
 
errorCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
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 an Exception.
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
 
ErrorMessagePublisher - Class in org.springframework.integration.support
The component which can be used as general purpose of errors publishing.
ErrorMessagePublisher() - Constructor for class org.springframework.integration.support.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 - 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.
ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
escapeRegexSpecials(String) - Static method in class org.springframework.integration.ip.util.RegexUtils
Escapes (precedes with \) any characters in the parameter in the set
ETAG - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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() - Method in interface org.springframework.integration.test.matcher.EqualsResultMatcher.Evaluator
 
evaluate(Object, String, Object...) - Static method in class org.springframework.integration.xml.xpath.XPathUtils
Utility method to evaluate an xpath on the provided object.
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
 
evaluatePayloadExpression(Object) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
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.
eventually(int, int, Matcher<U>) - Static method in class org.springframework.integration.test.matcher.EventuallyMatcher
 
eventually(Matcher<U>) - Static method in class org.springframework.integration.test.matcher.EventuallyMatcher
 
EventuallyMatcher<U> - Class in org.springframework.integration.test.matcher
A matcher that will evaluate another matcher repeatedly until it matches, or fail after some number of attempts.
EventuallyMatcher(Matcher<U>) - Constructor for class org.springframework.integration.test.matcher.EventuallyMatcher
 
EventuallyMatcher(Matcher<U>, int, int) - Constructor for class org.springframework.integration.test.matcher.EventuallyMatcher
 
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
exchange(Message<?>) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
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) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
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) - Method in interface org.springframework.integration.scripting.ScriptExecutor
 
executeScript(ScriptSource, Map<String, Object>) - Method in interface org.springframework.integration.scripting.ScriptExecutor
 
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
 
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 ChannelInterceptorAware extension for the cases when the ExecutorChannelInterceptors may have reason (e.g.
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 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
expect(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
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
 
expireGroup(Object, MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
expireMessageGroups(long) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
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.
EXPIRES - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
expireUnusedOlderThan(long) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
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.
ExponentialMovingAverage - Class in org.springframework.integration.support.management
Cumulative statistics for a series of real numbers with higher weight given to recent data.
ExponentialMovingAverage(int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverage
Create a moving average accumulator with decay lapse window provided.
ExponentialMovingAverage(int, double) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverage
Create a moving average accumulator with decay lapse window provided.
ExponentialMovingAverageRate - Class in org.springframework.integration.support.management
Cumulative statistics for an event rate with higher weight given to recent data.
ExponentialMovingAverageRate(double, double, int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
ExponentialMovingAverageRate(double, double, int, boolean) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
ExponentialMovingAverageRatio - Class in org.springframework.integration.support.management
Cumulative statistics for success ratio with higher weight given to recent data.
ExponentialMovingAverageRatio(double, int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
ExponentialMovingAverageRatio(double, int, boolean) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
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) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
 
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.
ExpressionEvaluatingMessageSource<T> - Class in org.springframework.integration.endpoint
 
ExpressionEvaluatingMessageSource(Expression, Class<T>) - Constructor for class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
ExpressionEvaluatingParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
 
ExpressionEvaluatingParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingParameterSourceFactory(BeanFactory) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that evaluates an expression.
ExpressionEvaluatingReleaseStrategy(String) - 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(Expression) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
 
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
 
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.
ExpressionUtils - Class in org.springframework.integration.expression
Utility class with static methods for helping with establishing environments for SpEL expressions.
ExpressionUtils() - Constructor for class org.springframework.integration.expression.ExpressionUtils
 
EXPUNGED - Static variable in class org.springframework.integration.mail.MailHeaders
 
extractAdviceChain(String, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
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() - 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
 
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<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
extractTypeIfPossible(Object, Class<H>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
extractTypeIfPossible(Object, Class<T>) - 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
 
FACTORY_BEAN_OBJECT_TYPE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
FAILED_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
The context key for the message object.
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.
failure() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with failed outcome.
failure(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with failed outcome at time t.
fatalWhenNoBeanFactory - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
Should be set to TRUE on CI plans and framework developer systems.
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(URL, String, FeedFetcher) - Constructor for class org.springframework.integration.feed.inbound.FeedEntryMessageSource
Creates a FeedEntryMessageSource that will use the provided FeedFetcher to read from the given feed URL.
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.
FileCopyingMultipartFileReader - Class in org.springframework.integration.http.multipart
MultipartFileReader implementation that copies the MulitpartFile'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.
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
 
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
 
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
 
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
 
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
 
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
 
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.
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
 
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
 
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
 
fileType - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
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 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.
FileWritingMessageHandlerFactoryBean - Class in org.springframework.integration.file.config
Factory bean used to create FileWritingMessageHandlers.
FileWritingMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
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(List<Method>) - Method in class org.springframework.integration.expression.ControlBusMethodFilter
 
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
 
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
 
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
Filters out files and returns the files that are left in a list, or an empty list when a null is passed in.
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
 
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
 
findAvailableServerSocket(int) - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a free available server socket (port) using the 'seed' value as the starting port.
findAvailableServerSocket() - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a free available server socket (port) using an automatically chosen start seed port.
findAvailableServerSockets(int, int) - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a free available server socket (port) using the 'seed' value as the starting port.
findAvailableUdpSocket(int) - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a free available Udp socket (port) using the 'seed' value as the starting port.
findAvailableUdpSocket() - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a free available Udp socket using an automatically chosen start seed port.
findAvailableUdpSockets(int, int) - Static method in class org.springframework.integration.test.util.SocketUtils
Determines free available udp socket(s) (port) using the 'seed' value as the starting port.
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
 
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
 
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
 
FixedSubscriberChannelBeanFactoryPostProcessor - Class in org.springframework.integration.config
Used to post process candidates for FixedSubscriberChannel MessageHandlers.
FLAGS - Static variable in class org.springframework.integration.mail.MailHeaders
 
flush() - Method in interface org.springframework.integration.jpa.core.JpaOperations
flush() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
flushableStore - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
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 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 open files.
flushIfNeeded() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
Flush the store if it's a Flushable and flushOnUpdate is true.
flushOnUpdate - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
folderOpenMode - Variable in class org.springframework.integration.mail.AbstractMailReceiver
 
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
 
forceComplete(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
formatDate(long) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
from(Map<String, ?>) - Static method in class org.springframework.integration.expression.ExpressionEvalMap
 
FROM - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
FROM - Static variable in class org.springframework.integration.mail.MailHeaders
 
FROM - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
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(Object, Class<T>) - 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, Class<T>) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
fromJson(Object, Type) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
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, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(P, Type) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
fromJson(P, Type) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
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 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.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
 
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
 
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
 
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
 
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
 
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
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
 
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<AbstractFileInfo<FTPFile>>) - Constructor for class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
Construct an instance with the supplied template and comparator.
Function<T,R> - Interface in org.springframework.integration.util
Implementations of this class perform work on the given parameter and return a result of an optionally different type.
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
 
FunctionIterator(Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
 

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_CONVERT_RECEIVE_MESSAGE - Static variable in class org.springframework.integration.context.IntegrationProperties
GatewayCompletableFutureProxyFactoryBean - Class in org.springframework.integration.gateway
A gateway proxy factory that can handle JDK8 CompletableFutures.
GatewayCompletableFutureProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
GatewayCompletableFutureProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
GatewayHeader - Annotation Type in org.springframework.integration.annotation
Provides the message header value or expression.
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 - 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
 
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
GemfireMessageStore(Cache) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
Deprecated.
- use the other constructor and provide a region directly.
GemfireMetadataStore - Class in org.springframework.integration.gemfire.metadata
Gemfire implementation of ConcurrentMetadataStore.
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() - 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
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(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, boolean) - 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(String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
get(int) - Method in class org.springframework.integration.history.MessageHistory
 
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(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getAckPort() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getActiveCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getActiveCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getActiveCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getActiveCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getActiveCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
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
 
getActiveCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getActiveCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getActiveHandlerCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getActiveHandlerCountLong() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
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
 
getAnnotationChain(Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getApplicationContext() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getApplicationContext() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getApplicationContextId() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Returns the ApplicationContext.getId() if the ApplicationContext is available.
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getArgs() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
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.
getBacklog() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
The number of sockets in the server connection backlog.
getBeanClass(Object) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
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.redis.config.RedisQueueInboundGatewayParser
 
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.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
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorChainParser
 
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
 
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
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
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.mail.MailReceivingMessageSource
 
getBeanFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getBeanFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getBeanName() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getBuffer() - Method in class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
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
 
getCause() - Method in class org.springframework.integration.event.IntegrationEvent
 
getChannel() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
getChannel() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getChannel() - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
getChannelCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelErrorRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getChannelInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return a read-only list of the configured interceptors.
getChannelInterceptors() - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
return the ChannelInterceptor list.
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
 
getChannelMappings() - Method in class org.springframework.integration.support.management.RouterMetrics
 
getChannelMetrics(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
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
 
getChannelNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
getChannelReceiveCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelReceiveCountLong(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelResolver() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getChannelSendCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelSendCountLong(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelSendErrorCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelSendErrorCountLong(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelSendRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getCharset() - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
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.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
 
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.
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
 
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.jms.ChannelPublishingJmsMessageListener
 
getComponentName() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
getComponentName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentName() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
getComponentName() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
getComponentName() - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
getComponentNamePatternsString() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
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.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.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.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.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.handler.AbstractMessageHandler
 
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.MethodInvokingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
getComponentType() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
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.TcpConnectionEventListeningMessageProducer
Deprecated.
 
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.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.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.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.MongoDbMessageSource
 
getComponentType() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
 
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.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.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
 
getComponentType() - Method in class org.springframework.integration.rmi.RmiOutboundGateway
 
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.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.support.management.graph.IntegrationNode
 
getComponentType() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
getComponentType() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
getComponentType() - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
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.twitter.inbound.DirectMessageReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.twitter.outbound.DirectMessageSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
 
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
 
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
 
getConnectHeaders() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
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.xmpp.config.XmppConnectionFactoryBean
 
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
 
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
 
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.support.management.graph.Graph
 
getContentType() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
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
 
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
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.xml.selector.AbstractXPathMessageSelector
 
getConvertibleTypes() - Method in class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
 
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.support.management.ExponentialMovingAverage
 
getCount() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getCount() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getCount() - Method in class org.springframework.integration.support.management.Statistics
 
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.
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getCountLong() - Method in class org.springframework.integration.support.management.Statistics
 
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
 
getCrossOrigin() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
getDefaultCountsEnabled() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
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.
getDefaultStatsEnabled() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
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.support.management.LifecycleMessageHandlerMetrics
 
getDelegate() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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.
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
getDescription(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMetadataMBeanInfoAssembler
 
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
 
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
 
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.
getDiscardChannelName() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscards() - Method in class org.springframework.integration.support.management.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
 
getDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
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.
getDynamicChannelNames() - Method in class org.springframework.integration.support.management.RouterMetrics
 
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.MessagingGatewaySupport
Return the error channel (if provided) to which error messages will be routed.
getErrorCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getErrorCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getErrorCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getErrorCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getErrorCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
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.
getErrorMessageStrategy() - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
getErrorRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getErrorRate() - Method in class org.springframework.integration.channel.NullChannel
 
getErrorRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getErrorRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getErrorRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getErrorRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableCompositeMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableDiscardingMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableEndpointNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableMessageHandlerNode
 
getErrors() - Method in interface org.springframework.integration.support.management.graph.ErrorCapableNode
 
getErrors() - Method in class org.springframework.integration.support.management.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
 
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.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.
getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.ValueExpression
 
getExpressionString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
getFactoryLocator() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Return this factory's locator.
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
 
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.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.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.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.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) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getFirstParameterType() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getFolder() - 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.
getFrom() - Method in class org.springframework.integration.support.management.graph.LinkNode
 
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
 
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
 
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.
getGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
 
getGraph() - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
Return the cached graph.
getGroupId() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
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.mongodb.store.ConfigurableMongoDbMessageStore
 
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
 
getHandleCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getHandleCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getHandleCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getHandleCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getHandleCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getHandleCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getHandleCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
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
 
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 class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlerDuration(String) - 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
 
getHandlerMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getHandlerNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlerNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Returns an unmodifiable Set of this dispatcher's handlers.
getHandlers() - Method in interface org.springframework.integration.handler.CompositeMessageHandler
Return an unmodifiable list of handlers.
getHandlers() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getHandlers() - Method in class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode
 
getHeader(String, Class<T>) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getHeader(Map<?, ?>, String) - Static method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
SpEL Function to retrieve a required header.
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getHeaderExpressions() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getHeaderMapper() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getHeaders() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
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
 
getHeaders() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
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
 
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
 
getHttpHeader(HttpHeaders, String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getId() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getId() - Method in interface org.springframework.integration.leader.Candidate
Gets the identifier.
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
 
getInetAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getInitialDelay() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
getInput() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode
 
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
 
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.redis.config.RedisOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.twitter.config.TwitterSearchOutboundGatewayParser
 
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
 
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
 
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
Exposes the interceptor list for subclasses.
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).
getJavaMailProperties() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getJdbcCallOperationsCacheStatistics() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Allows for the retrieval of metrics (CacheStats) for the GuavaCacheWrapper#jdbcCallOperationsCache, which is used to store instances of SimpleJdbcCallOperations.
getJdbcCallOperationsCacheStatisticsAsMap() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Allows for the retrieval of metrics (CacheStats) for the GuavaCacheWrapper#jdbcCallOperationsCache.
getJdbcOperations() - Method in class org.springframework.integration.jdbc.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.
getKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
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
 
getLazyLifecycleRoles() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getLevel() - Method in class org.springframework.integration.handler.LoggingHandler
 
getLineCount() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getLinks() - Method in class org.springframework.integration.support.management.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
 
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.AbstractMessageHandler
 
getManagedName() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getManagedName() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getManagedName() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getManagedName() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
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.AbstractMessageHandler
 
getManagedType() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getManagedType() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getManagedType() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getManagedType() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
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.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
 
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.support.management.ExponentialMovingAverage
 
getMax() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMax() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMax() - Method in class org.springframework.integration.support.management.Statistics
 
getMaxAge() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getMaxConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getMaxDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMaxDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMaxDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMaxDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMaxDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMaxDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
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
 
getMaxSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMaxSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMaxSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMean() - Method in class org.springframework.integration.support.management.Statistics
 
getMeanDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMeanDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMeanDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMeanDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMeanDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMeanDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanErrorRate() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanErrorRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanErrorRatio() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanErrorRatio() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanSendRate() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanSendRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
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
 
getMessage(UUID) - Method in class org.springframework.integration.jdbc.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(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 class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
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.handler.advice.IdempotentReceiverInterceptor
 
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.MailReceivingMessageSource
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
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
 
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.endpoint.AbstractMessageSource
 
getMessageCount() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getMessageCount() - Method in class org.springframework.integration.jdbc.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
 
getMessageCount() - Method in class org.springframework.integration.support.management.graph.MessageSourceNode.Stats
 
getMessageCount() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getMessageCount() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.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.
getMessageCountLong() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getMessageCountLong() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getMessageCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getMessageCountLong() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Not fully used.
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.JdbcMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Method not implemented.
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
 
getMessageId() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getMessageIds() - Method in class org.springframework.integration.store.MessageGroupMetadata
Obtain a LinkedList copy of the MessageGroupMetadata.messageIds stored in the group.
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 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.SimpleMessageGroup
 
getMessages() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
 
getMessages() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.jdbc.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
 
getMessagingTemplate() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getMessagingTemplate() - Method in class org.springframework.integration.router.AbstractMessageRouter
Provides MessagingTemplate access for subclasses
getMetadataStore(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
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.channel.AbstractMessageChannel
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMin() - Method in class org.springframework.integration.support.management.Statistics
 
getMinDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMinDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMinDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMinDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMinDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMinDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getMinimumTimeoutForEmptyGroups() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMinSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMinSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMinSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
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
 
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.history.MessageHistory.Entry
 
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.support.management.graph.CompositeMessageHandlerNode.InnerHandler
 
getName() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
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.support.management.graph.IntegrationNode
 
getNodes() - Method in class org.springframework.integration.support.management.graph.Graph
 
getNotPropagatedHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Get the header names 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.file.config.FileReadingMessageSourceFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
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
 
getObjectName(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMetadataNamingStrategy
 
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.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.jpa.outbound.JpaOutboundGatewayFactoryBean
 
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
 
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.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.
getOption() - Method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
 
getOrder() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
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.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
getOrder() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
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
 
getOriginalMessage() - Method in class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
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.support.management.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.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
 
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(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getPathPatterns() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getPatterns() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
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
 
getPayload() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getPayloadExpression() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getPayloadType() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
getPeriod() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
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
 
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.endpoint.AbstractEndpoint
 
getPhase() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
 
getPhase() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getPhase() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
getPhase() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getPhase() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
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.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.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
 
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
 
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.udp.UnicastReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
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
 
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
 
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
 
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.support.management.graph.IntegrationNode
 
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
 
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.integration.test.util.TestUtils
 
getQos() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getQos() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getQuery(JdbcMessageStore.Query) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Replace patterns in the input to produce a valid SQL query.
getQuery(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
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
 
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.
getQueueSize() - Method in interface org.springframework.integration.support.management.QueueChannelManagement
 
getRabbitTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getRandomSeedPort() - Static method in class org.springframework.integration.test.util.SocketUtils
Determines a random seed port number within the port range 10000 and 60000.
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
 
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
 
getReceiveCount() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
getReceiveCount() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveCount() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
getReceiveCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveCount() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveCountLong() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
getReceiveCountLong() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveCountLong() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
getReceiveCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveCountLong() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveErrorCount() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
getReceiveErrorCount() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveErrorCount() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
getReceiveErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveErrorCount() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveErrorCountLong() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
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
 
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
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
Subclasses implement this to get provided registrations.
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
 
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
 
getRemainingCapacity() - Method in interface org.springframework.integration.support.management.QueueChannelManagement
 
getRemoteDirectory() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
getRemoteDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
 
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
 
getRemoteSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getRemoveBatchSize() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getReply() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getReplyChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
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.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
 
getRequestMapping() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
getRequestMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
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.leader.AbstractCandidate
 
getRole() - Method in interface org.springframework.integration.leader.Candidate
Gets the role.
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.support.management.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
 
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
 
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
 
getSecureObjectClass() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
getSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSendCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendCount() - Method in class org.springframework.integration.channel.NullChannel
 
getSendCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendCount() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendCount() - Method in class org.springframework.integration.support.management.graph.MessageGatewayNode.Stats
 
getSendCount() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendCountLong() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendCountLong() - Method in class org.springframework.integration.channel.NullChannel
 
getSendCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendCountLong() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
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
 
getSendErrorCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendErrorCount() - Method in class org.springframework.integration.channel.NullChannel
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendErrorCount() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendErrorCountLong() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendErrorCountLong() - Method in class org.springframework.integration.channel.NullChannel
 
getSendErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendErrorCountLong() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendRate() - Method in class org.springframework.integration.channel.NullChannel
 
getSendRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
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() - 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() - 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
 
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.session.AbstractFtpSessionFactory
 
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
 
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.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
 
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
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSourceCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceMessageCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceMessageCountLong(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceMetrics(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getSourceNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
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
 
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
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.Statistics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getStandardDeviationSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getStats() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
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.
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.
getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
getSupportedProtocols() - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
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
 
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
 
getTimeSinceLastMeasurement() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getTimeSinceLastMeasurement() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getTimeSinceLastSend() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getTimeSinceLastSend() - Method in class org.springframework.integration.channel.NullChannel
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getTimeSinceLastSend() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
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.SimpleMessageGroup
 
getTimestamp(RFC5424SyslogParser.Reader) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser
Default implementation returns the date as a String (if present).
getTimeUnit() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
getTo() - Method in class org.springframework.integration.support.management.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
 
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
 
getTransformOnSend() - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
getTransientHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Return the transient header names.
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTwitter() - Method in class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getType() - Method in class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode.InnerHandler
 
getType() - Method in class org.springframework.integration.support.management.graph.LinkNode
 
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.
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.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 interface org.springframework.integration.jpa.support.parametersource.ParameterSource
Return the parameter value for the requested named parameter.
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.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.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
 
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.support.management.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.support.management.graph.Graph
 
GRAPH_CONTROLLER_BEAN_NAME - Static variable in class org.springframework.integration.http.support.HttpContextUtils
Represents the bean name for the default IntegrationGraphController.
GRAPH_CONTROLLER_DEFAULT_PATH - Static variable in class org.springframework.integration.http.support.HttpContextUtils
Represents the default request mapping path for the IntegrationGraphController.
GRAPH_CONTROLLER_PATH_PROPERTY - Static variable in class org.springframework.integration.http.support.HttpContextUtils
Represents the environment property for the IntegrationGraphController request mapping path.
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
 
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
 
groupIdQuery(Object) - Static method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 

H

H2ChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
 
H2ChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
handle(String) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
handle(Exception) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
 
handleConfirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
handleCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
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.test.support.AbstractResponseValidator
handle the message
HandleMessageAdvice - Interface in org.springframework.integration.handler.advice
The marker MethodInterceptor interface extension to distinguish advices for some reason.
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.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.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.mqtt.outbound.AbstractMqttMessageHandler
 
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.twitter.outbound.DirectMessageSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
 
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
 
handleMessageToClient(WebSocketSession, Message<?>) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
handleNotification(Notification, Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Notification handling method implementation.
HANDLER_ALIAS_SUFFIX - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
HANDLER_MAPPING_BEAN_NAME - Static variable in class org.springframework.integration.http.support.HttpContextUtils
 
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.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.ServiceActivatingHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
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.redis.outbound.RedisOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
 
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.twitter.outbound.TwitterSearchOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
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(T) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasEntry(T, V) - Static method in class org.springframework.integration.test.matcher.MapContentMatchers
 
hasEntry(T, Matcher<V>) - Static method in class org.springframework.integration.test.matcher.MapContentMatchers
 
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
 
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 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.support.MutableMessage
 
hashCode() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
hashCode() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
hasHeader(String, T) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasHeader(String, Matcher<?>) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasHeaderKey(String) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasKey(T) - Static method in class org.springframework.integration.test.matcher.MapContentMatchers
 
hasMessageId(T) - Static method in class org.springframework.integration.test.matcher.HeaderMatcher
 
hasNext() - Method in class org.springframework.integration.util.FunctionIterator
 
hasPayload(T) - Static method in class org.springframework.integration.test.matcher.PayloadMatcher
 
hasPayload(Matcher<? super T>) - Static method in class org.springframework.integration.test.matcher.PayloadMatcher
 
hasRealSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
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 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 - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Header. Will be removed in a future release.
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.
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
 
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
 
HeaderMapper<T> - Interface in org.springframework.integration.mapping
Generic strategy interface for mapping MessageHeaders to and from other types of objects.
headerMapper - Variable in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
headerMapper - Variable in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
HeaderMatcher - 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 - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Headers. Will be removed in a future release.
HEADERS - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
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 - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
HOST - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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_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.support
Utility class for accessing HTTP integration components from the BeanFactory.
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
 
HttpIntegrationConfigurationInitializer - Class in org.springframework.integration.http.config
The HTTP Integration infrastructure beanFactory initializer.
HttpIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.http.config.HttpIntegrationConfigurationInitializer
 
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
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
 
HttpRequestHandlingEndpointSupport(boolean) - Constructor for class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
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 - Static variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
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
 
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.
idx - Variable in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
IF_MATCH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
IF_MODIFIED_SINCE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
IF_NONE_MATCH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
IF_RANGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
IF_UNMODIFIED_SINCE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
imap(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
ImapHandler(Socket) - Constructor for class org.springframework.integration.test.mail.TestMailServer.ImapServer.ImapHandler
 
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
 
ImapIdleExceptionEvent(Exception) - Constructor for class org.springframework.integration.mail.ImapIdleChannelAdapter.ImapIdleExceptionEvent
 
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
 
ImapServer(int) - Constructor for class org.springframework.integration.test.mail.TestMailServer.ImapServer
 
InboundChannelAdapter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of producing a Message or Message payload.
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
 
InboundFileSynchronizer - Interface in org.springframework.integration.file.remote.synchronizer
Strategy for synchronizing from a remote File system to a local directory.
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.
inboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
inboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
increment() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
Add a new event to the series.
increment(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
Add a new event to the series at time t.
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
 
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.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
 
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.twitter.config.TwitterNamespaceHandler
 
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
 
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.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.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 - Variable in class org.springframework.integration.mail.AbstractMailReceiver
 
initialized - Variable in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
initialized - Variable in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
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.support.management.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.
InputStreamCallback - Interface in org.springframework.integration.file.remote
Callback for stream-based file retrieval using a RemoteFileOperations.
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
 
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
 
IntegrationConfigurationBeanFactoryPostProcessor - Class in org.springframework.integration.config
BeanFactoryPostProcessor 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
 
IntegrationEvaluationContextAware - Interface in org.springframework.integration.expression
Deprecated.
since 4.2 in favor of IntegrationContextUtils.getEvaluationContext(org.springframework.beans.factory.BeanFactory) direct usage from the afterPropertiesSet implementation. Will be removed in the next release.
IntegrationEvaluationContextAwareBeanPostProcessor - Class in org.springframework.integration.expression
Deprecated.
since 4.2 in favor of IntegrationContextUtils.getEvaluationContext(org.springframework.beans.factory.BeanFactory) direct usage from the afterPropertiesSet implementation. Will be removed in the next release.
IntegrationEvaluationContextAwareBeanPostProcessor() - Constructor for class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
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.event
Base class for all ApplicationEvents generated by the framework.
IntegrationEvent(Object) - Constructor for class org.springframework.integration.event.IntegrationEvent
 
IntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.event.IntegrationEvent
 
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.support.management.graph
Builds the runtime object model graph.
IntegrationGraphServer() - Constructor for class org.springframework.integration.support.management.graph.IntegrationGraphServer
 
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.
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.support.management
Configures beans that implement IntegrationManagement.
IntegrationManagementConfigurer() - Constructor for class org.springframework.integration.support.management.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
 
IntegrationMetadataMBeanInfoAssembler - Class in org.springframework.integration.monitor
The MetadataMBeanInfoAssembler extension to assemble metadata MBean info from the LifecycleMessageSourceMetrics or LifecycleMessageHandlerMetrics managed bean's delegate.
IntegrationMetadataMBeanInfoAssembler(JmxAttributeSource) - Constructor for class org.springframework.integration.monitor.IntegrationMetadataMBeanInfoAssembler
 
IntegrationMetadataNamingStrategy - Class in org.springframework.integration.monitor
The MetadataNamingStrategy naming extension to extract an ObjectName from the LifecycleMessageSourceMetrics or LifecycleMessageHandlerMetrics managed bean's delegate.
IntegrationMetadataNamingStrategy(JmxAttributeSource) - Constructor for class org.springframework.integration.monitor.IntegrationMetadataNamingStrategy
 
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.support.management.graph
Base class for all nodes.
IntegrationNode(int, String, Object, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.IntegrationNode
 
IntegrationNode.Stats - Class in org.springframework.integration.support.management.graph
 
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
 
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'.
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
 
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
 
IntegrationStatsManagement - Interface in org.springframework.integration.support.management
Base interface containing methods to control complete statistics gathering.
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.
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
 
INTERCEPTOR_FACTORY_CHAIN - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
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.scheduling.PollSkipAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
invoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
IP_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The ip address from which a TCP message or UDP packet was received.
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
 
isAcknowledge() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
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
 
isAsync() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
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.endpoint.AbstractEndpoint
 
isAutoStartup() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
 
isAutoStartup() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
isAutoStartup() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
We are controlled by the startup options of the bound endpoint.
isAutoStartup() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
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.redis.channel.SubscribableRedisChannel
 
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.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
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.IntegrationNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageGatewayNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageSourceNode.Stats
 
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.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
 
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.
isCountsEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isCountsEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isCountsEnabled() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
isCountsEnabled() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
isCountsEnabled() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isCountsEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
isDigit() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
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.gateway.FtpOutboundGateway
 
isDirectory() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
isDirectory(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
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.redis.config.RedisQueueInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
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
 
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.HttpRequestHandlingEndpointSupport
 
isExtractPayload() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
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
 
isFixedRate() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
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.
isFullStatsEnabled() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
isFullStatsEnabled() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
isHandler(Class<?>) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
isInputShutdown() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Deprecated.
since 4.3.10 in favor of JacksonPresent
isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonPresent
 
isJacksonPresent() - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Deprecated.
since 4.3.10 in favor of JacksonPresent
isJacksonPresent() - Static method in class org.springframework.integration.support.json.JacksonPresent
 
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.AbstractMessageHandler
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isLoggingEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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
 
isLost() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
isMapToPayload() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
isModified() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.CompositeHeaderMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
 
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.PatternBasedHeaderMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
isNoReadErrorOnClose() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
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
 
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
 
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
 
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.
isReceiveOnlyAdvice(Advice) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
isReleasePartialSequences() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isRequiresReply() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
isRetained() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
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.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.file.WatchServiceDirectoryScanner
Deprecated.
 
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.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.ServiceActivatingHandler
 
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.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.monitor.ManagedEndpoint
 
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.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 class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isRunning() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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.util.MessagingMethodInvokerHelper
 
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.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.ConsumerEndpointFactoryBean
 
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.SourcePollingChannelAdapterFactoryBean
 
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.file.config.FileReadingMessageSourceFactoryBean
 
isSingleton() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
isSingleton() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
isSingleton() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
isSingleton() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
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
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
isStale(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when an idle item is retrieved from the pool.
isStatsEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isStatsEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isStatsEnabled() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isStatsEnabled() - Method in interface org.springframework.integration.support.management.IntegrationStatsManagement
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isTimeoutOnIdle() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
isTimeoutOnIdle() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
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.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.JdbcMessageStore
 
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.
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
A LockRegistry 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
Implementation of MessageStore using a relational database via JDBC.
JdbcMessageStore() - Constructor for class org.springframework.integration.jdbc.JdbcMessageStore
Deprecated.
JdbcMessageStore(DataSource) - Constructor for class org.springframework.integration.jdbc.JdbcMessageStore
Create a MessageStore with all mandatory properties.
JdbcMessageStore(JdbcOperations) - Constructor for class org.springframework.integration.jdbc.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
 
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
 
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
 
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
 
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
 
JmsHeaders - Class in org.springframework.integration.jms
Deprecated.
- use JmsHeaders. Will be removed in the Spring Integration 5.0.
JmsHeaders() - Constructor for class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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
 
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
 
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
 
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
 
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
 
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.
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.
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
 
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
 
JpaOutboundGatewayFactoryBean(JpaExecutor) - Constructor for class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
Deprecated.
since 4.2.5 in favor of JpaOutboundGatewayFactoryBean.setJpaExecutor(JpaExecutor) to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
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 namesspace 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.
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.
JsonObjectMapperAdapter<N,P> - Class in org.springframework.integration.support.json
Simple JsonObjectMapper adapter implementation, if there is no need to provide entire operations implementation.
JsonObjectMapperAdapter() - Constructor for class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
JsonObjectMapperProvider - Class in org.springframework.integration.support.json
Simple factory to provide JsonObjectMapper instances dependently of jackson-databind or boon libs 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 on Jackson JSON objects.
JsonPropertyAccessor() - Constructor for class org.springframework.integration.json.JsonPropertyAccessor
 
JsonPropertyAccessor.ToStringFriendlyJsonNode - Class in org.springframework.integration.json
 
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(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<?>, JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
JsonToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 

K

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
 
keySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
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(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
 
language - Variable in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
LAST_MODIFIED - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
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
 
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
 
LeaderInitiatorFactoryBean(CuratorFramework, String, String) - Constructor for class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
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
 
level() - Method in enum org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
lifecycleCondition - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
lifecycleLock - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
LifecycleMessageHandlerMetrics - Class in org.springframework.integration.support.management
A MessageHandlerMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageHandlerMetrics(Lifecycle, MessageHandlerMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
LifecycleMessageSourceMetrics - Class in org.springframework.integration.support.management
A MessageSourceMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageSourceMetrics(Lifecycle, MessageSourceMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
LifecycleTrackableMessageHandlerMetrics - Class in org.springframework.integration.support.management
LifecycleTrackableMessageHandlerMetrics(Lifecycle, MessageHandlerMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
LifecycleTrackableMessageSourceMetrics - Class in org.springframework.integration.support.management
LifecycleTrackableMessageSourceMetrics(Lifecycle, MessageSourceMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
LINE_COUNT - Static variable in class org.springframework.integration.mail.MailHeaders
 
LinkNode - Class in org.springframework.integration.support.management.graph
Represents a link between nodes.
LinkNode(int, int, LinkNode.Type) - Constructor for class org.springframework.integration.support.management.graph.LinkNode
 
LinkNode.Type - Enum in org.springframework.integration.support.management.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
 
listEligibleFiles(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Subclasses may refine the listing strategy by overriding this method.
listEligibleFiles(File) - Method in class org.springframework.integration.file.RecursiveLeafOnlyDirectoryScanner
Deprecated.
 
listEligibleFiles(File) - Method in class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
 
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
 
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.
listIterator() - Method in class org.springframework.integration.history.MessageHistory
 
listIterator(int) - Method in class org.springframework.integration.history.MessageHistory
 
listLocks() - Method in class org.springframework.integration.redis.util.RedisLockRegistry
Deprecated.
since 4.3.10, will be removed in 5.0 to avoid deserialized locks created in different process
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
 
LoadBalancingStrategy - Interface in org.springframework.integration.dispatcher
Strategy for determining the iteration order of a MessageHandler list.
LOCAL_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The local address (InetAddress) that the socket is connected to.
locateComponentInHistory(List<Properties>, String, int) - Static method in class org.springframework.integration.test.util.TestUtils
 
LOCATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
Tries to lock the given file and returns true if it was successful, false otherwise.
LOCK_REGISTRY_REGION - Static variable in class org.springframework.integration.gemfire.util.GemfireLockRegistry
 
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
 
Log4jClassLevelAdjuster - Class in org.springframework.integration.test.rule
Similar to Log4jLevelAdjuster that can be applied as a @ClassRule but you will not get a log message indicating breaks between tests.
Log4jClassLevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.integration.test.rule.Log4jClassLevelAdjuster
 
Log4jClassLevelAdjuster(Level, String...) - Constructor for class org.springframework.integration.test.rule.Log4jClassLevelAdjuster
 
Log4jLevelAdjuster - Class in org.springframework.integration.test.rule
A JUnit method @Rule that changes the logger level for a set of classes or packages while a test method is running.
Log4jLevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.integration.test.rule.Log4jLevelAdjuster
 
Log4jLevelAdjuster(Level, String...) - Constructor for class org.springframework.integration.test.rule.Log4jLevelAdjuster
 
LogAdjustingTestSupport - Class in org.springframework.integration.test.support
Base class for module tests where logging is set to TRACE for the duration of the test and reverted to the previous value.
LogAdjustingTestSupport() - Constructor for class org.springframework.integration.test.support.LogAdjustingTestSupport
 
LogAdjustingTestSupport(String...) - Constructor for class org.springframework.integration.test.support.LogAdjustingTestSupport
 
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.config.xml.AbstractIntegrationNamespaceHandler
 
logger - Variable in class org.springframework.integration.context.IntegrationObjectSupport
Logger that is available to subclasses
logger - Variable in class org.springframework.integration.dispatcher.AbstractDispatcher
 
logger - Variable in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
logger - Variable in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
logger - Variable in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
 
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.mail.AbstractMailReceiver
 
logger - Variable in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
logger - Variable in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
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.ErrorMessagePublisher
 
logger - Variable in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
logger - Variable in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
logger - Variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
logger - Variable in class org.springframework.integration.test.support.LogAdjustingTestSupport
 
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
 
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
 
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
 
LOOKUP_HOST - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
ls(Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 

M

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) - Constructor for class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
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.
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
 
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.
MailServer(int) - Constructor for class org.springframework.integration.test.mail.TestMailServer.MailServer
 
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.
ManagedEndpoint - Class in org.springframework.integration.monitor
Wrapper for an AbstractEndpoint that exposes a management interface.
ManagedEndpoint(AbstractEndpoint) - Constructor for class org.springframework.integration.monitor.ManagedEndpoint
 
MANAGEMENT_CONFIGURER_NAME - Static variable in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
managementConfigurer() - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
MAP_KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
 
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.HttpRequestExecutingMessageHandler
 
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) - Static method in class org.springframework.integration.amqp.support.MappingUtils
Map an o.s.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
 
MAPPER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
MappingMessageRouterManagement - Interface in org.springframework.integration.support.management
Exposes channel mapping operations when the router is proxied.
mappingMongoConverter - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
MappingUtils - Class in org.springframework.integration.amqp.support
Utility methods used during message mapping.
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
 
mapToPayload - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
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)
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
 
matches(Object, Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
matches(Object, Description) - Method in class org.springframework.integration.test.matcher.EventuallyMatcher
 
matches(Object) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
matches(Method) - Method in class org.springframework.integration.util.UniqueMethodFilter
 
matchesSafely(Message<?>) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
Subclasses should implement this.
matchesSafely(Map<? super T, ? super V>) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
Subclasses should implement this.
matchesSafely(Message) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
Subclasses should implement this.
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_FORWARDS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
MAX_MESSAGES_UNBOUNDED - Static variable in class org.springframework.integration.scheduling.PollerMetadata
 
maxMessageSize - Variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
maxSubscribers - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
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
 
MentionsReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
Receives Message Tweets
MentionsReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
 
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.
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_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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_SOURCE - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
 
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 - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
MessageBuilderFactory - Interface in org.springframework.integration.support
 
MessageChannelMetrics - Interface in org.springframework.integration.support.management
Interface for all message channel monitors containing accessors for various useful metrics that are generic for all channel types.
MessageChannelNode - Class in org.springframework.integration.support.management.graph
Represents a message channel.
MessageChannelNode(int, String, MessageChannel) - Constructor for class org.springframework.integration.support.management.graph.MessageChannelNode
 
MessageChannelNode.Stats - Class in org.springframework.integration.support.management.graph
 
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 messsage 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.
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.
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(int) - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
 
MessageCountReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
Convenient constructor is only one message is required (threshold=1).
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
 
MessageEndpoint - Annotation Type in org.springframework.integration.annotation
Stereotype annotation indicating that a class is capable of serving as a Message Endpoint.
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.
messageFromEvent(TcpConnectionEvent) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
Deprecated.
 
MessageGatewayNode - Class in org.springframework.integration.support.management.graph
Represents an inbound gateway.
MessageGatewayNode(int, String, MessagingGatewaySupport, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageGatewayNode
 
MessageGatewayNode.Stats - Class in org.springframework.integration.support.management.graph
 
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.JdbcMessageStore
 
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.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
 
MessageHandlerMetrics - Interface in org.springframework.integration.support.management
 
MessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents a message handler.
MessageHandlerNode(int, String, MessageHandler, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageHandlerNode
 
MessageHandlerNode.Stats - Class in org.springframework.integration.support.management.graph
 
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.
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
 
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
 
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
 
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
 
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<T> - Interface in org.springframework.integration.handler
This defines the lowest-level strategy of processing a Message and returning some Object (or null).
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.support.management.graph
Represents an inbound message producer.
MessageProducerNode(int, String, MessageProducerSupport, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageProducerNode
 
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
 
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(WhiteListDeserializingConverter, 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.
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
 
MessageSequenceComparator - Class in org.springframework.integration.aggregator
A Comparator implementation based on the 'sequence number' property of a Message's header.
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.
MessageSourceMetrics - Interface in org.springframework.integration.support.management
 
MessageSourceNode - Class in org.springframework.integration.support.management.graph
Represents a message source.
MessageSourceNode(int, String, MessageSource<?>, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageSourceNode
 
MessageSourceNode.Stats - Class in org.springframework.integration.support.management.graph
 
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
 
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
 
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
 
MessageTransformingChannelInterceptor - Class in org.springframework.integration.transformer
Deprecated.
It is not generally recommended to perform functions such as transformation in a channel interceptor.
MessageTransformingChannelInterceptor(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
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<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
 
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
 
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<T> - Class in org.springframework.integration.util
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.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Method, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper.ParametersWrapper - Class in org.springframework.integration.util
 
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
 
messagingTemplate - Variable in class org.springframework.integration.support.ErrorMessagePublisher
 
METADATA_STORE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
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
 
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
 
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
 
MetricsContext - Interface in org.springframework.integration.support.management
Interface representing an opaque object containing state between initiating an event and concluding it.
MetricsFactory - Interface in org.springframework.integration.support.management
Factories implementing this interface provide metric objects for message channels and message handlers.
mGet(Message<?>, Session<F>, String, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
MIN_REGISTRATION_VALUE - Static variable in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
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
 
MockitoMessageMatchers - Class in org.springframework.integration.test.matcher
Mockito matcher factory for Message matcher creation.
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
 
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(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDbFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
 
MongoDbChannelMessageStore(MongoDbFactory, 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
 
MongoDbMessageBytesConverter - Class in org.springframework.integration.mongodb.support
A GenericConverter implementation to convert Message to serialized byte[] to store Message to the MongoDB.
MongoDbMessageBytesConverter() - Constructor for class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
 
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(MongoDbFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Creates an instance with the provided MongoDbFactory 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(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
Create a MongoDbMessageStore using the provided MongoDbFactory.and the default collection name.
MongoDbMessageStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
Create a MongoDbMessageStore using the provided MongoDbFactory and collection name.
MongoDbMetadataStore - Class in org.springframework.integration.mongodb.metadata
MongoDbMetadataStore implementation of ConcurrentMetadataStore.
MongoDbMetadataStore(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoDbFactory and default collection name - MongoDbMetadataStore.DEFAULT_COLLECTION_NAME.
MongoDbMetadataStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
Configure the MongoDbMetadataStore by provided MongoDbFactory 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
 
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(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
Will construct this instance using provided MongoDbFactory
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
mongoTemplate - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
mqttBytesToPayload(MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
Subclasses can override this method to convert the byte[] to a payload.
MqttConnectionFailedEvent - Class in org.springframework.integration.mqtt.event
 
MqttConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.mqtt.event.MqttConnectionFailedEvent
 
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
 
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 URL 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 URL when you don't need additional MqttConnectOptions.
MqttParserUtils - Class in org.springframework.integration.mqtt.config.xml
Contains various utility methods for parsing Mqtt Adapter specific namespace elements as well as for the generation of the the respective BeanDefinitions.
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
Contains utility methods used by the MqttAdapter components.
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.
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
 
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
 
MutableMessageBuilder<T> - Class in org.springframework.integration.support
 
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
 
MutableMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the MutableMessage.
MutableMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
 
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 - Variable in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
name - Variable in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
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
 
newCount - Variable in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext
 
newCount - Variable in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext
 
newInstance() - Static method in class org.springframework.integration.support.json.JsonObjectMapperProvider
Return an object mapper if available.
newInstance() - Static method in class org.springframework.integration.xml.TransformerFactoryUtils
Build a new TransformerFactory using the default constructor.
newInstance(Class<? extends TransformerFactory>) - Static method in class org.springframework.integration.xml.TransformerFactoryUtils
Build an TransformerFactory and prevent external entities from accessing.
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
 
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
 
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_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
 
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
 
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
 
NUMBER - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
 

O

OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
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
Will transform an object graph into a Map.
ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
 
ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
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
 
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
 
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(AmqpAdmin, String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
 
obtainQueueName(AmqpAdmin, 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
 
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
 
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.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(TcpConnectionEvent) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
Deprecated.
 
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(ContextRefreshedEvent) - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
 
onApplicationEvent(AbstractLeaderEvent) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
 
onClose(Connection) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
onCreate(Connection) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
ONE_MINUTE_SECONDS - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
ONE_SECOND_SECONDS - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
 
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
 
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.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.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.handler.FileTransferringMessageHandler
 
onInit() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
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.AbstractMessageHandler
 
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.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.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.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.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.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.outbound.MongoDbStoringMessageHandler
 
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.redis.channel.SubscribableRedisChannel
 
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.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.rmi.RmiInboundGateway
 
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.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.twitter.outbound.StatusUpdatingMessageHandler
 
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
 
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.
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
 
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.
onSend(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
Deprecated.
with no replacement. Redundant method.
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
 
open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
 
open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
 
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() - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
Deprecated.
since 4.3.20
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 - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
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
 
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.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.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.endpoint - package org.springframework.integration.endpoint
Provides core classes related to Endpoints.
org.springframework.integration.event - package org.springframework.integration.event
ApplicationEvents generated by the Spring Integration framework.
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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.graph - package org.springframework.integration.support.management.graph
Provides classes related to the runtime object graph.
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.mail - package org.springframework.integration.test.mail
 
org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
Provides several BaseMatcher implementations.
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.twitter.config - package org.springframework.integration.twitter.config
Contains parser classes for the Twitter namespace support.
org.springframework.integration.twitter.core - package org.springframework.integration.twitter.core
Provides classes used across all Twitter components.
org.springframework.integration.twitter.inbound - package org.springframework.integration.twitter.inbound
Provides inbound Twitter components.
org.springframework.integration.twitter.outbound - package org.springframework.integration.twitter.outbound
Provides outbound Twitter components.
org.springframework.integration.util - package org.springframework.integration.util
Provides core utility classes.
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.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.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
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
 
OutboundGatewayType - Enum in org.springframework.integration.jpa.support
Indicates the mode of operation for the outbound Jpa Gateway.
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.
outboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
outboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 

P

PACKET_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
The remote address for a UDP packet.
ParameterSource - Interface in org.springframework.integration.jpa.support.parametersource
 
ParameterSourceFactory - Interface in org.springframework.integration.jpa.support.parametersource
 
ParametersWrapper(Message<?>) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
ParametersWrapper(Collection<Message<?>>, Map<String, ?>) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
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
 
parseCommon(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.mqtt.config.xml.MqttParserUtils
 
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.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.twitter.config.TwitterOutboundChannelAdapterParser
 
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.redis.config.RedisOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.twitter.config.TwitterSearchOutboundGatewayParser
 
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
 
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.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
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.twitter.config.TwitterInboundChannelAdapterParser
 
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
 
parseWithHeaders(JsonParser, String) - 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
 
PASSCODE - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
PassThroughMessageGroupProcessor - Class in org.springframework.integration.aggregator
Deprecated.
PassThroughMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
Deprecated.
 
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 - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
pathFor(String) - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
Return the path for the key.
PatternBasedHeaderMatcher(Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
Payload - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Payload. Will be removed in a future release.
PayloadAndHeaderMatcher - 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
 
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
 
PayloadMatcher - 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.
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
 
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 - 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.handler.advice.ErrorMessageSendingRecoverer
 
payloadWhenNull(AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Build a Throwable payload based on the provided context for future ErrorMessage when there is original Throwable.
peek() - Method in class org.springframework.integration.store.MessageGroupQueue
 
peek() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
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 - Enum in org.springframework.integration.jpa.support
Indicates how entities shall be persisted to the underlying persistence store.
PHASE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
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, SimpleMessageListenerContainer, 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, SimpleMessageListenerContainer, 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() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
poll(Message<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute a (typically retrieving) JPA operation.
poll() - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute the 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.
PollableChannelManagement - Interface in org.springframework.integration.support.management
Metrics for pollable channels.
PollableJmsChannel - Class in org.springframework.integration.jms
 
PollableJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.PollableJmsChannel
 
Poller - Annotation Type in org.springframework.integration.annotation
Provides the PollerMetadata options for the Messaging annotations for polled endpoints.
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
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.DirectMessageReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
 
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
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
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.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.
pool - Variable in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
Pool<T> - Interface in org.springframework.integration.util
Represents a pool of items.
pop3(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
Pop3Handler(Socket) - Constructor for class org.springframework.integration.test.mail.TestMailServer.Pop3Server.Pop3Handler
 
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
 
Pop3Server(int) - Constructor for class org.springframework.integration.test.mail.TestMailServer.Pop3Server
 
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
 
populateJavaTypes(Map<String, Object>, Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
populateMBeanDescriptor(Descriptor, Object, String) - Method in class org.springframework.integration.monitor.IntegrationMetadataMBeanInfoAssembler
 
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>, 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 - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
PORT - Static variable in class org.springframework.integration.ip.IpHeaders
The remote port for a UDP packet.
PositionSupportingParameterSource - Interface in org.springframework.integration.jpa.support.parametersource
 
POST_PROCESS_DYNAMIC_BEANS - Static variable in class org.springframework.integration.context.IntegrationProperties
Whether BeanPostProcessors should process beans registered at runtime.
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.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.aop.PublisherAnnotationBeanPostProcessor
 
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.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
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
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
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.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
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
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
No-Op.
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
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
PRAGMA - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
prefix - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
 
PREFIX - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
Prefix used for JMS API related headers in order to distinguish from user-defined headers and other internal headers (e.g.
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
 
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.ws.WebServiceHeaders
 
PREFIX - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
PrefixBasedMatcher(boolean, String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
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 Messages when a 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.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
prev() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
PRIORITY - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
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(int, Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
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() - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
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.util.MessagingMethodInvokerHelper
 
process(Collection<Message<?>>, Map<String, ?>) - Method in class org.springframework.integration.util.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.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 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 interface org.springframework.integration.aggregator.MessageGroupProcessor
Process the given MessageGroup.
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
Deprecated.
 
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.
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
 
PropertiesPersistingMetadataStore - Class in org.springframework.integration.metadata
Properties file-based implementation of MetadataStore.
PropertiesPersistingMetadataStore() - Constructor for class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
PROXY_AUTHENTICATE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
PROXY_AUTHORIZATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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(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
 
publish(MessagingException) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Throwable) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Message<?>, MessagingException) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Message<?>, Throwable) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied throwable and context.
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(Class<? extends Annotation>...) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationAdvisor() - 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
 
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
 
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
 
PublishSubscribeAmqpChannel - Class in org.springframework.integration.amqp.channel
 
PublishSubscribeAmqpChannel(String, SimpleMessageListenerContainer, 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, SimpleMessageListenerContainer, 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 - Class in org.springframework.integration.channel
A channel that sends Messages to each of its subscribers.
PublishSubscribeChannel(Executor) - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will use an Executor to invoke the handlers.
PublishSubscribeChannel() - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will invoke the handlers in the message sender's thread.
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
 
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
 
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(String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
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(String, Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
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 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
 
putLifecycleInRole(String, String, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
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
 
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.
QueueChannelManagement - Interface in org.springframework.integration.support.management
 
QueueChannelOperations - Interface in org.springframework.integration.channel
Operations available on a channel that has queuing semantics.
queueSemaphore - Variable in class org.springframework.integration.channel.QueueChannel
 

R

RANGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
RAW_HEADERS - Static variable in class org.springframework.integration.mail.MailHeaders
 
Reactor2TcpStompSessionManager - Class in org.springframework.integration.stomp
Reactor2TcpStompSessionManager(Reactor2TcpStompClient) - Constructor for class org.springframework.integration.stomp.Reactor2TcpStompSessionManager
 
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
Reads 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
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
Reads 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
 
readOnlyHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
 
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.support.management.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() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
receive() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
receive() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
receive() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Execute the query.
receive() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
Executes the query.
receive() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Will receive a JMS Message converting and returning it as a Spring Integration Message.
receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
Uses JpaExecutor.poll() to executes the JPA operation.
receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
receive() - Method in interface org.springframework.integration.mail.MailReceiver
 
receive() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
receive() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
Will execute a Query returning its results as the Message payload.
receive() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
Returns a Message with the view into a RedisStore identified by RedisStoreMessageSource.keyExpression
receive() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
receive() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
receiveCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
RECEIVED_DATE - Static variable in class org.springframework.integration.mail.MailHeaders
 
receiveErrorCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
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
 
Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
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
 
recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
 
recursiveFindAnnotation(Class<? extends Annotation>, Annotation, List<Annotation>, Set<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
RecursiveLeafOnlyDirectoryScanner - Class in org.springframework.integration.file
Deprecated.
in favor of FileReadingMessageSource.setUseWatchService(boolean) (when using Java 7 or later)
RecursiveLeafOnlyDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveLeafOnlyDirectoryScanner
Deprecated.
 
REDELIVERED - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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 LockRegistry 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 and a default local DefaultLockRegistry.
RedisLockRegistry(RedisConnectionFactory, String, long) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
Constructs a lock registry with the supplied lock expiration and a default local DefaultLockRegistry.
RedisLockRegistry(RedisConnectionFactory, String, long, LockRegistry) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
Deprecated.
since 4.3.10, will be removed in 5.0, - the localRegistry isn't used any more
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 MetadataStore.
RedisMetadataStore(RedisProperties) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
Specifies the RedisProperties backend for this MetadataStore.
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
 
REFERER - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
refreshGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
 
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.
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
 
registerBeanDefinitionDecorator(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionDecoratorForAttribute(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionParser(String, BeanDefinitionParser) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
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
 
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.
registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
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).
registerRoleControllerDefinitionIfNecessary(BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
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.
registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
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.
registerWebSocketHandlers(WebSocketHandlerRegistry) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
RegistrationIds - Class in org.springframework.integration.codec.kryo
Default registration ids for serializers provided by the framework.
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.springframework.integration.util.CallerBlocksPolicy
 
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.
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.
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.
ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a ReleaseStrategy.
ReleaseStrategyFactoryBean() - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
ReleaseStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
ReleaseStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
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
 
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_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
The remote port from which a TCP message was received.
REMOTE_SESSION - Static variable in class org.springframework.integration.file.FileHeaders
Deprecated.
- use IntegrationMessageHeaderAccessor#CLOSEABLE_RESOURCE.
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
 
RemoteFileOperations<F> - Interface in org.springframework.integration.file.remote
Strategy for performing operations on remote files.
RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
 
RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
remoteFileTemplate - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
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.
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
 
remove(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
remove(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
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 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(Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
remove() - Method in class org.springframework.integration.util.FunctionIterator
 
remove(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
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.
removeChannelMapping(String) - Method in class org.springframework.integration.support.management.RouterMetrics
 
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
 
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 interface org.springframework.integration.channel.ChannelInterceptorAware
Remove the provided ChannelInterceptor from the target implementation.
removeInterceptor(int) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
Remove a ChannelInterceptor from the target implementation for specific index.
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
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.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
 
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
Deprecated.
removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
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.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, 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
 
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.
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
 
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
 
replace(String, String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
 
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.
replaceChannelMappings(Properties) - Method in class org.springframework.integration.support.management.RouterMetrics
 
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.jms.JmsHeaders
Deprecated.
 
REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
 
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
 
ReplyContainerProperties() - Constructor for class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
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
 
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
 
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
 
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
 
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
REQUIRE_COMPONENT_ANNOTATION - Static variable in class org.springframework.integration.context.IntegrationProperties
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
 
ResequencerParser - Class in org.springframework.integration.config.xml
Parser for the <resequencer> element.
ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
 
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.channel.AbstractMessageChannel
 
reset() - Method in class org.springframework.integration.channel.NullChannel
 
reset() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
reset() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
reset() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
reset() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
Resume polling at the next Trigger event.
reset() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
Reset all counters/statistics.
reset() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
reset() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
reset() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
reset() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
reset() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
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.
resolve(String, Message<?>) - Method in interface org.springframework.integration.redis.outbound.ArgumentsStrategy
 
resolve(String, Message<?>) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
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.
resolveDestination(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
resolveErrorChannel(MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
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
 
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.
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
 
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_AFTER - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
RetryExceptionNotAvailableException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException
 
RetryStateGenerator - Interface in org.springframework.integration.handler.advice
Strategy interface for generating a RetryState instance based on a message.
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(Message, int, String, String, String) - 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.
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.
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
An inbound Messaging Gateway for RMI-based remoting.
RmiInboundGateway() - Constructor for class org.springframework.integration.rmi.RmiInboundGateway
 
RmiInboundGatewayParser - Class in org.springframework.integration.rmi.config
Parser for the <inbound-gateway/> element of the 'rmi' namespace.
RmiInboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
RmiNamespaceHandler - Class in org.springframework.integration.rmi.config
Namespace handler for Spring Integration's rmi namespace.
RmiNamespaceHandler() - Constructor for class org.springframework.integration.rmi.config.RmiNamespaceHandler
 
RmiOutboundGateway - Class in org.springframework.integration.rmi
An outbound Messaging Gateway for RMI-based remoting.
RmiOutboundGateway(String) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
Construct an instance with a `RequestReplyExchanger` built from the default RmiProxyFactoryBean.
RmiOutboundGateway(String, RmiOutboundGateway.RmiProxyFactoryBeanConfigurer) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
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
Allows configuration of the proxy factory bean before the RMI proxy is created.
RmiOutboundGatewayParser - Class in org.springframework.integration.rmi.config
Parser for the <outbound-gateway/> element of the 'rmi' namespace.
RmiOutboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
 
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
 
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
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.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.synchronizer.AbstractInboundFileSynchronizer
 
RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
Round-robin implementation of LoadBalancingStrategy.
RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
 
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
 
RouterMetrics - Class in org.springframework.integration.support.management
Allows Router operations to appear in the same MBean as statistics.
RouterMetrics(Lifecycle, MappingMessageRouterManagement) - Constructor for class org.springframework.integration.support.management.RouterMetrics
 
ROUTING_SLIP - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
RoutingMessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents an endpoint that can route to multiple channels.
RoutingMessageHandlerNode(int, String, MessageHandler, String, String, Collection<String>) - Constructor for class org.springframework.integration.support.management.graph.RoutingMessageHandlerNode
 
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.
RubyScriptExecutor - Class in org.springframework.integration.scripting.jsr223
 
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<?>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
SAVED_KEY - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
SAVED_KEY - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
SAVED_KEY - Static variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
SAVED_KEY - Static variable in class org.springframework.integration.mongodb.store.MongoDbMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
sb - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
 
ScatterGatherHandler - Class in org.springframework.integration.scattergather
The MessageHandler implementation for the Scatter-Gather EIP pattern.
ScatterGatherHandler(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
 
ScatterGatherHandler(MessageHandler, 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
 
SCHEDULER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
scriptEngine - Variable in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
ScriptExecutingMessageProcessor - Class in org.springframework.integration.scripting.jsr223
 
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
 
ScriptExecutor - Interface in org.springframework.integration.scripting
 
ScriptExecutorFactory - Class in org.springframework.integration.scripting.jsr223
 
ScriptExecutorFactory() - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
 
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
 
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
 
ScriptParser() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
ScriptVariableGenerator - Interface in org.springframework.integration.scripting
Strategy interface to provide a Map of variables to the script execution context.
SEARCH_METADATA - Static variable in class org.springframework.integration.twitter.core.TwitterHeaders
 
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
 
SearchReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
 
SearchReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
searchReply(String) - Method in class org.springframework.integration.test.mail.TestMailServer.ImapServer.ImapHandler
 
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
 
SelectorChainParser - Class in org.springframework.integration.config.xml
Parser for the <selector-chain/> element.
SelectorChainParser() - Constructor for class org.springframework.integration.config.xml.SelectorChainParser
 
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
 
semaphore - Variable in class org.springframework.integration.util.UpperBound
 
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<?>) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
 
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
 
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
 
sendCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendDuration - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendErrorCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
sendErrorMessageIfNecessary(Message<?>, RuntimeException) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Send an error message based on the exception and message.
sendErrorRate - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendExceptionToListener(Exception) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
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
 
sendRate - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendSuccessRatio - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
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
 
SequenceNumberComparator - Class in org.springframework.integration.aggregator
 
SequenceNumberComparator() - Constructor for class org.springframework.integration.aggregator.SequenceNumberComparator
 
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
 
SequenceSizeReleaseStrategy(boolean) - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
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
Writes 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
 
serializeWithType(MessageHeaders, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
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.http.support.DefaultHttpHeaderMapper
 
SERVER - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
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
 
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
 
SERVLET_PRESENT - Static variable in class org.springframework.integration.http.support.HttpContextUtils
The boolean flag to indicate if the org.springframework.web.servlet.DispatcherServlet is present in the CLASSPATH to allow to register the Integration server components, e.g.
Session<F> - Interface in org.springframework.integration.file.remote.session
Common abstraction for a Session with a remote File system.
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
 
SessionCallback<F,T> - Interface in org.springframework.integration.file.remote
Callback invoked by RemoteFileOperations.execute() - allows multiple operations on a session.
SessionCallbackWithoutResult<F> - Class in org.springframework.integration.file.remote
Simple convenience implementation of SessionCallback for cases where no result is returned.
SessionCallbackWithoutResult() - Constructor for class org.springframework.integration.file.remote.SessionCallbackWithoutResult
 
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.
sessions - Variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
 
SET_COOKIE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
 
setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
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
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
 
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.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
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) - 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, TimeUnit) - 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.
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).
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.context.IntegrationObjectSupport
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
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.support.management.graph.IntegrationGraphServer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
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.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.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.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.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.support.management.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
 
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.handler.FileTransferringMessageHandler
 
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
 
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.file.WatchServiceDirectoryScanner
Deprecated.
 
setAutoStartup(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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.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
 
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.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.IntegrationRegistrar
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
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.jpa.outbound.JpaOutboundGatewayFactoryBean
 
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.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.support.json.BoonJsonObjectMapper
 
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.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.channel.MessagePublishingErrorHandler
 
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.MessagingTemplate
Overridden to set the destination resolver to a BeanFactoryChannelResolver.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
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.IdempotentReceiverInterceptor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
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.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.udp.DatagramPacketMessageMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
 
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.config.MailReceiverFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
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.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.store.AbstractMessageGroupStore
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
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.support.ErrorMessagePublisher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
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.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.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.FileTailInboundChannelAdapterFactoryBean
 
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.mail.MailReceivingMessageSource
 
setBeanName(String) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
setBeanName(String) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
setBeanName(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
setBeanName(String) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setBeforeCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setBeforeCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
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
 
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
 
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.
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.support.ErrorMessagePublisher
 
setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
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.
setChannelMapping(String, String) - Method in class org.springframework.integration.support.management.RouterMetrics
 
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.
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.support.management.RouterMetrics
 
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.support.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.support.ErrorMessagePublisher
 
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.handler.FileTransferringMessageHandler
 
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.HttpRequestExecutingMessageHandler
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(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.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
 
setCleanSession(Boolean) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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
 
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.
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.outbound.MongoDbStoringMessageHandler
Sets the SpEL Expression that should resolve to a collection name used by MongoOperations to store data
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.
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
 
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(int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
Set the completion timeout for operations.
setCompletionTimeout(int) - 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.jms.ChannelPublishingJmsMessageListener
 
setComponentName(String) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
Sets the name of the handler component.
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
 
setConfirmCorrelationExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
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).
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.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.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.
setConnectionTimeout(Integer) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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
 
setConnectTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Set the connect timeout for the socket.
setConnectTimeout(long) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
Specify the the timeout in milliseconds to wait for the STOMP session establishment.
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
 
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.config.AggregatorFactoryBean
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setCountsEnabled(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setCountsEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
setCrossOrigin(CrossOrigin) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Set the CrossOrigin to permit cross origin requests for this endpoint.
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.
setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Deprecated.
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.
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
 
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.
setDefaultCountsEnabled(Boolean) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set whether managed components maintain message counts by default.
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.support.management.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
 
setDefaultQos(int) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
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.
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.
setDefaultRetained(boolean) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
setDefaultStatsEnabled(Boolean) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set whether managed components maintain message statistics by default.
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
 
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.
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.
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.
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<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A converter for deserializing byte arrays to messages.
setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
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.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.
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.filter.MessageFilter
 
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.
setDisconnectDelay(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setDurable(boolean) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
 
setDurableSubscriptionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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
 
setEmbeddedValueResolver(StringValueResolver) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setEnableDaemonThread(Boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
If true, all threads will be daemon threads.
setEnabledCountsPatterns(String[]) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set the array of simple patterns for component names for which message counts will be enabled (defaults to '*').
setEnabledStatsPatterns(String[]) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set the array of simple patterns for component names for which message statistics will be enabled (response times, rates etc), as well as counts (a positive match here overrides enabledCountsPatterns, you can't have statistics without counts).
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.HttpRequestExecutingMessageHandler
Specify whether the real URI should be encoded after uriVariables expanding and before send request via RestTemplate.
setEncodeUri(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Specify whether the URI should be encoded after any uriVariables are expanded and before sending the request.
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
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.
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.
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.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.stomp.inbound.StompInboundChannelAdapter
 
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.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.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(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
 
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.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.support.ErrorMessagePublisher
 
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.
setEventTypes(Class<? extends TcpConnectionEvent>[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
Deprecated.
Set the list of event types (classes that extend TcpConnectionEvent) 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
 
setExchangeNameExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
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
 
setExistsMode(FtpRemoteFileTemplate.ExistsMode) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
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.
setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
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
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
 
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.HttpRequestExecutingMessageHandler
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
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.
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
 
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
Expire (completely remove) a group if it is completed due to 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.
setExpiryCallbacks(Collection<MessageGroupStore.MessageGroupCallback>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
Convenient injection point for expiry callbacks in the message store.
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).
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.handler.LoggingHandler
setExpression(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
setExpression(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
 
setExpressionCommand(Expression) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
setExpressionConfirmCorrelation(Expression) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
setExpressionExchangeName(Expression) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
setExpressionOnFailure(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the root message after a failed handler invocation.
setExpressionOnSuccess(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the message after a successful handler invocation.
setExpressionPayload(Expression) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
setExpressionRename(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
setExpressionRoutingKey(Expression) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
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.
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.HttpRequestExecutingMessageHandler
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.RedisQueueInboundGateway
 
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.xml.transformer.MarshallingTransformer
Specify whether the source Message's payload should be extracted prior to marshalling.
setExtractPayload(boolean) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
Deprecated.
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.HttpRequestHandlingEndpointSupport
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.
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.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.handler.FileTransferringMessageHandler
 
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
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
 
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.
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.
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
 
setFullStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
When false, simple counts are maintained; when true complete statistics are maintained.
setFullStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
When false, simple counts are maintained; when true complete statistics are maintained.
setFunctions(Map<String, Method>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
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
 
setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
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(MessageHandler) - 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).
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.HttpRequestHandlingEndpointSupport
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.outbound.AbstractAmqpOutboundEndpoint
 
setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
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.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(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
 
setHeadersMap(Map<String, String>) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
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.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.HttpRequestExecutingMessageHandler
Specify the HttpMethod for requests.
setHttpMethodExpression(Expression) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify the SpEL Expression to determine HttpMethod dynamically
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)
setIdleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
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.
setIgnoreJta(boolean) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
Deprecated.
with no-op, in favor of externally configured region.
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
 
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.
setInitialDelay(long) - 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 inital ID value.
setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setIntegrationEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.IntegrationEvaluationContextAware
Deprecated.
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
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
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
 
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
 
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(List<ChannelInterceptor>) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
Populate the ChannelInterceptors to the target implementation.
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(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 (SimpleJdbcCall) instances to be held by GuavaCacheWrapper#jdbcCallOperationsCache.
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Deprecated.
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.
setKeepAliveInterval(Integer) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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.redis.outbound.RedisStoreWritingMessageHandler
Specifies a SpEL Expression to be used to determine the key for the Redis store.
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.
setKnownHosts(String) - 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.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
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
 
setLevel(LoggingHandler.Level) - Method in class org.springframework.integration.handler.LoggingHandler
Set the logging LoggingHandler.Level to change the behavior at runtime.
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.JdbcMessageStore
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.JdbcChannelMessageStore
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 specfic 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
 
setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
setLocalDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
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
 
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.
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.AbstractMessageHandler
 
setLoggingEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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.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.AbstractMessageHandler
 
setManagedName(String) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setManagedName(String) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setManagedName(String) - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
setManagedName(String) - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
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.AbstractMessageHandler
 
setManagedType(String) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setManagedType(String) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setManagedType(String) - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
setManagedType(String) - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
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.
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(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
 
setMaxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
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
 
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.
setMaxRowsPerPoll(Integer) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
The maximum number of rows to pull out of the query results per poll (if greater than zero, otherwise all rows will be packed into the outgoing message).
setMaxRowsPerPoll(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
The maximum number of rows to pull out of the query results per poll (if greater than zero, otherwise all rows will be packed into the outgoing message).
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.
setMean(double) - Method in class org.springframework.integration.support.management.Statistics
 
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
 
setMessageCodec(SockJsMessageCodec) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
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.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(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
 
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
 
setMessageListener(WebSocketListener) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
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
 
setMetadataStore(MetadataStore) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
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
 
setMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMetricsFactory(MetricsFactory) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set a metrics factory.
setMetricsFactoryBeanName(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set a metrics factory bean name.
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.outbound.MongoDbStoringMessageHandler
Allows you to provide 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
 
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.
setMutableMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MutableMessageHeaders.
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.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
 
setNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
Rare property - not exposed through namespace
setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
How often we clean up closed NIO connections if soTimeout is 0.
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.handler.AbstractMessageProducingHandler
Set headers 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.
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(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
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.
setOnSuccessExpression(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
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.
setOptions(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
setOptions(String) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
setOrder(int) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
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.AbstractMessageHandler
 
setOrder(int) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
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.jpa.outbound.JpaOutboundGatewayFactoryBean
 
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.AggregatorFactoryBean
 
setOutputChannelName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.handler.AbstractMessageProducingHandler
 
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
 
setPassword(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setPassword(String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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(Pattern) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
setPattern(String) - 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(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setPayloadExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
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.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.
setPeriod(long) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify the period of the trigger.
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.file.WatchServiceDirectoryScanner
Deprecated.
setPhase(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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.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.
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.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.
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.
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(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the JMS priority to use when sending request Messages.
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
 
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.
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.
setPublisherMetadataSource(PublisherMetadataSource) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
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
 
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.
setQuery(String) - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
setQueryExpression(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
setQueryExpressionReference(QueryExp) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
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
 
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
 
setReactorEnvironment(Object) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Deprecated.
with no-op in favor of global JVM-wide Reactor configuration.
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.
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
 
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.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).
setRecoveryCallback(RecoveryCallback<? extends Object>) - 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
 
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.JdbcMessageStore
A unique grouping identifier for all messages persisted with this store.
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.store.JdbcChannelMessageStore
A unique grouping identifier for all messages persisted with this store.
setRegistryHost(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setRegistryPort(int) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Set releasePartialSequences on an underlying 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.handler.FileTransferringMessageHandler
 
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.
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
 
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
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
 
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
 
setRenameExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
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.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.JmsOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
 
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.GatewayMethodMetadata
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel name.
setReplyChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
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.
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 HttpRequestHandlingEndpointSupport.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.
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(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.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.MessagingGatewaySupport
Set the request channel.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiInboundGateway
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.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.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.
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.HttpRequestHandlingEndpointSupport
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(Class<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Specify the type of payload to be generated when the inbound HTTP request content is read by the HttpMessageConverters.
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(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.transformer.ContentEnricher
Set the timeout value for sending request messages.
setRequireComponentAnnotation(boolean) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
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
 
setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
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
 
setReturnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
Set the channel to which returned messages are sent.
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.zookeeper.config.LeaderInitiatorFactoryBean
 
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
 
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
 
setRunning(boolean) - Method in class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
 
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
setSearchArgsExpression(Expression) - Method in class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
An expression that is used to build the search; must resolve to a SearchParameters object, or a String, in which case the default page size of 20 is applied, or a list of up to 4 arguments, such as "{payload, headers.pageSize, headers.sinceId, headers.maxId}".
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
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.
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
 
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
 
setSendTimeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
setSendTimeout(long) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
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.FilterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
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.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.support.ErrorMessagePublisher
 
setSendTimeout(long) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
setSequence(int) - 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
 
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<? super Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A converter for serializing messages to byte arrays for storage.
setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
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.
setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
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.
setServerURIs(String...) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the interface class that the generated proxy should implement.
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.
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.AbstractMessageHandler
 
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.support.management.LifecycleTrackableMessageHandlerMetrics
 
setShouldTrack(boolean) - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
setShouldTrack(boolean) - Method in interface org.springframework.integration.support.management.TrackableComponent
 
setShouldTrack(boolean) - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
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
setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
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.mqtt.core.DefaultMqttPahoClientFactory
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
 
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
 
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.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.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
 
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
 
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
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.
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.
setSslProperties(Properties) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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, ?>) - 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).
setStatsEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setStatsEnabled(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setStatsEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationStatsManagement
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setStatusCodeExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
Specify the Expression to resolve a status code for Response to override the default '200 OK'.
setStatusCodeIfNeeded(ServletServerHttpResponse) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
setStopTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
Deprecated.
since 4.3 with no-op in favor of delayer call callback.run() in the AbstractEndpoint.stop(Runnable).
setStopTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
Deprecated.
since 4.3 with no-op in favor of delayer call callback.run() in the AbstractEndpoint.stop(Runnable).
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
 
setStringToBytes(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Sets whether outbound String payloads are to be converted to byte[].
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
 
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
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.
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.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.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.aggregator.AbstractCorrelatingMessageHandler
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
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
 
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
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
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.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.
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.config.RouterFactoryBean
Deprecated.
setTimeout(long) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify the timeout value for sending to the discard channel.
setTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
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).
setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
Allows you to override the rule for the timeout calculation.
setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Allows you to override the rule for the timeout calculation.
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.
setTimeUnit(TimeUnit) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
setTopic(String) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setTopicExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
setTopicPatterns(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setTopics(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
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.HttpRequestExecutingMessageHandler
Set to true if you wish 'Set-Cookie' headers in responses to be transferred as 'Cookie' headers in subsequent interactions for a message.
setTransformOnSend(boolean) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
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.HttpRequestExecutingMessageHandler
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
 
setTweetDataExpression(Expression) - Method in class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
An expression that is used to build the TweetData; must resolve to a TweetData object, or a String, or a Tweet.
setTxAdviceChain(List<Advice>) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
 
setTxSize(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
setType(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
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
 
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.JdbcMessageHandler
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
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.HttpRequestExecutingMessageHandler
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.HttpRequestExecutingMessageHandler
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
 
setUserName(String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
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 based on the Java 7 WatchService.
setUseWeakReferences(boolean) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
Deprecated.
since 4.3.10, will be removed in 5.0, - the thread local cache isn't used any more
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
 
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.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.
setValueResolver(StringValueResolver) - Method in class org.springframework.integration.monitor.IntegrationJmxAttributeSource
 
setValues(PreparedStatement, Message<?>) - Method in interface org.springframework.integration.jdbc.MessagePreparedStatementSetter
 
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
 
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.
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.
setWebSocketEnabled(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
 
setWhiteListPatterns(String...) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Set simple patterns for allowable packages/classes for deserialization.
setWhiteListPatterns(String...) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
When using a WhiteListDeserializingConverter (the default) add patterns for packages/classes that are allowed to be deserialized.
setWill(DefaultMqttPahoClientFactory.Will) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
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
 
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
 
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
 
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
 
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
 
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
 
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
 
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<AbstractFileInfo<ChannelSftp.LsEntry>>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
Construct an instance with the supplied template and comparator.
SharedSessionCapable - Interface in org.springframework.integration.file.remote.session
A SessionFactory that implements this interface is capable of supporting a shared session.
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.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.
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) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.FlushPredicate
 
shouldFlush(String, long, Message<?>) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.MessageFlushPredicate
 
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.jms.config.JmsMessageDrivenEndpointParser
 
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.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, ChannelInterceptorAware) - Method in interface org.springframework.integration.channel.interceptor.VetoCapableInterceptor
 
shouldIntercept(String, ChannelInterceptorAware) - Method in class org.springframework.integration.channel.interceptor.WireTap
 
shouldMapInboundHeader(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
shouldSplitOutput(Iterable<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
SIMPLE_CALLBACK - Static variable in class org.springframework.integration.expression.ExpressionEvalMap
 
SimpleActiveIdleMessageSourceAdvice - Class in org.springframework.integration.aop
A simple advice that polls at one rate when messages exist and another when there are no messages.
SimpleActiveIdleMessageSourceAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
 
SimpleIncrementingIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
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
 
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
 
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
 
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
 
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
 
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 - 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.
smtp(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
 
SmtpHandler(Socket) - Constructor for class org.springframework.integration.test.mail.TestMailServer.SmtpServer.SmtpHandler
 
SmtpServer(int) - Constructor for class org.springframework.integration.test.mail.TestMailServer.SmtpServer
 
SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
SoapHeaderMapper - Interface in org.springframework.integration.ws
A convenience interface that extends HeaderMapper but parameterized with SoapHeader.
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
 
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
 
SocketUtils - Class in org.springframework.integration.test.util
Contains several socket-specific utility methods.
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.
SOURCE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
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
 
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
 
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
 
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.
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
 
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
 
SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
Collaborator for JDBC adapters which allows creation of instances of SqlParameterSource for use in update operations.
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_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
 
start() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
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 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.file.WatchServiceDirectoryScanner
Deprecated.
 
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.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.ServiceActivatingHandler
 
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.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.monitor.ManagedEndpoint
 
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.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 - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics.DefaultChannelMetricsContext
 
start - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext
 
start() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
start() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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.util.MessagingMethodInvokerHelper
 
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.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
 
startLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Start all registered SmartLifecycles in the role.
StaticHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
StaticHeaderValueMessageProcessor(T) - Constructor for class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
 
Statistics - Class in org.springframework.integration.support.management
 
Statistics(long, double, double, double, double) - Constructor for class org.springframework.integration.support.management.Statistics
 
Stats() - Constructor for class org.springframework.integration.support.management.graph.IntegrationNode.Stats
 
STATUS_CODE - Static variable in class org.springframework.integration.http.HttpHeaders
 
StatusUpdatingMessageHandler - Class in org.springframework.integration.twitter.outbound
MessageHandler for sending regular status updates as well as 'replies' or 'mentions'.
StatusUpdatingMessageHandler(Twitter) - Constructor for class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
 
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
 
stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
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 AbstractSingleBeanDefinitionParser 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 ApplicationEvents 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.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 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.file.WatchServiceDirectoryScanner
Deprecated.
 
stop(Runnable) - Method in class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
 
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.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.ServiceActivatingHandler
 
stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop(Runnable) - 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(Runnable) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Stops the server.
stop(Runnable) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
stop(Runnable) - 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.TcpOutboundGateway
 
stop() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
stop(Runnable) - 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.monitor.ManagedEndpoint
 
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.scattergather.ScatterGatherHandler
 
stop(Runnable) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
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(Runnable) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop(Runnable) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
stop() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Stop the registration of the LockRegistryLeaderInitiator.candidate for leader election.
stop() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
stop() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
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.util.MessagingMethodInvokerHelper
 
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(Runnable) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
stop() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
stop(Runnable) - 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(Runnable) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
stop() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
stop(Runnable) - 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.
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.
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
 
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
 
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
 
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
 
SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
 
SUBJECT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
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
 
SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
 
SubscribableRedisChannel - Class in org.springframework.integration.redis.channel
 
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(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
SUBSCRIPTION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
 
success() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with successful outcome.
success(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with successful outcome at time t.
suggestedClassName() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
supplyCustomHeaders(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Override to provide additional headers.
supportedJsonTypes - 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
 
supportsEventType(ResolvableType) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
supportsSourceType(Class<?>) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
synchronizeToLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
synchronizeToLocalDirectory(File) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
 
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
 
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

TAG - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
TAG - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
take() - Method in class org.springframework.integration.store.MessageGroupQueue
 
takeLeadership(CuratorFramework) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.LeaderListener
 
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.
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
 
TcpConnectionEventInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
Deprecated.
in favor of the generic event adapter.
TcpConnectionEventInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpConnectionEventInboundChannelAdapterParser
Deprecated.
 
TcpConnectionEventListeningMessageProducer - Class in org.springframework.integration.ip.tcp.connection
Deprecated.
in favor of using the generic ApplicationEventListeningMessageProducer which can now more efficiently filter required events. Configure the adapter to handle TcpConnectionEvent.
TcpConnectionEventListeningMessageProducer() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
Deprecated.
 
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 TcpConnectionIntercepters; 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
 
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
 
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
Constructs a TcpNetConnection for the socket.
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
 
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
 
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.
TcpSocketFactorySupport - Interface in org.springframework.integration.ip.tcp.connection
Strategy interface for supplying Socket Factories.
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
 
TE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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.ImapServer.ImapHandler - 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.Pop3Server.Pop3Handler - Class in org.springframework.integration.test.mail
 
TestMailServer.SmtpServer - Class in org.springframework.integration.test.mail
 
TestMailServer.SmtpServer.SmtpHandler - Class in org.springframework.integration.test.mail
 
testName - Variable in class org.springframework.integration.test.support.LogAdjustingTestSupport
 
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.TestApplicationContext - Class in org.springframework.integration.test.util
 
THREAD - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
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
TimelineReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
This MessageSource lets Spring Integration consume given account's timeline as messages.
TimelineReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
 
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, 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
 
TIMESTAMP - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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
 
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
 
toCommand(String) - Static method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
 
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(Object) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
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
 
toJson(Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJsonNode(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toMap() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.codec.CodecMessageConverter
 
toMessage(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
 
toMessage(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
toMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
toMessage(T) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
 
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(String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
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 - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
 
topicLock - Variable in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
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 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.event.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.file.remote.AbstractFileInfo
 
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.filter.ExpressionEvaluatingSelector
 
toString() - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
 
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.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.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.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.message.EnhancedErrorMessage
Deprecated.
 
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.scripting.RefreshableResourceScriptSource
 
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.management.DefaultMessageChannelMetrics
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
toString() - Method in class org.springframework.integration.support.management.Statistics
 
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.MessagingMethodInvokerHelper
 
toString() - Method in class org.springframework.integration.util.UpperBound
 
ToStringFriendlyJsonNode(JsonNode) - Constructor for class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
TrackableComponent - Interface in org.springframework.integration.support.management
 
TrackableRouterMetrics - Class in org.springframework.integration.support.management
TrackableRouterMetrics(Lifecycle, MappingMessageRouterManagement) - Constructor for class org.springframework.integration.support.management.TrackableRouterMetrics
 
TRAILER - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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
TRANSFER_ENCODING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
transferTo(File) - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
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.
TransformerAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @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
 
TransformerFactoryUtils - Class in org.springframework.integration.xml
The TransformerFactory configuration wrapper with some common settings.
TransformerParser - Class in org.springframework.integration.config.xml
Parser for the <transformer/> element.
TransformerParser() - Constructor for class org.springframework.integration.config.xml.TransformerParser
 
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(byte[]) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
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(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
Claim the file to process.
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
 
TwitterHeaders - Class in org.springframework.integration.twitter.core
Header keys used by the various Twitter adapters.
TwitterInboundChannelAdapterParser - Class in org.springframework.integration.twitter.config
Parser for inbound Twitter Channel Adapters.
TwitterInboundChannelAdapterParser() - Constructor for class org.springframework.integration.twitter.config.TwitterInboundChannelAdapterParser
 
TwitterNamespaceHandler - Class in org.springframework.integration.twitter.config
Namespace handler for the Twitter adapters.
TwitterNamespaceHandler() - Constructor for class org.springframework.integration.twitter.config.TwitterNamespaceHandler
 
TwitterOutboundChannelAdapterParser - Class in org.springframework.integration.twitter.config
Parser for all outbound Twitter adapters
TwitterOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.twitter.config.TwitterOutboundChannelAdapterParser
 
TwitterSearchOutboundGateway - Class in org.springframework.integration.twitter.outbound
The AbstractReplyProducingMessageHandler implementation to perform request/reply Twitter search with SearchParameters as the result of TwitterSearchOutboundGateway.searchArgsExpression expression evaluation.
TwitterSearchOutboundGateway(Twitter) - Constructor for class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
 
TwitterSearchOutboundGatewayParser - Class in org.springframework.integration.twitter.config
Parser for <int-twitter:search-outbound-gateway/>.
TwitterSearchOutboundGatewayParser() - Constructor for class org.springframework.integration.twitter.config.TwitterSearchOutboundGatewayParser
 
TYPE - Static variable in class org.springframework.integration.jms.JmsHeaders
Deprecated.
 
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
 

U

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
 
UdpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
 
UdpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
 
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
 
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.
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
 
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
 
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.redis.channel.SubscribableRedisChannel
 
unwrapExceptionIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
Unwrap the cause of a AbstractRequestHandlerAdvice.ThrowableHolderException.
unwrapThrowableIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
Unwrap the cause of a AbstractRequestHandlerAdvice.ThrowableHolderException.
updateAckAddress() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
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
 
UPGRADE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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.
USER_AGENT - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
USER_PRINCIPAL - Static variable in class org.springframework.integration.http.HttpHeaders
 
username - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
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

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
 
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.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.handler.LoggingHandler.Level
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.mqtt.core.ConsumerStopAction
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.support.management.graph.LinkNode.Type
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.
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.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.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.mqtt.core.ConsumerStopAction
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.support.management.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.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.
VARY - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
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.
VIA - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 

W

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.
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.
WARNING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
was(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
WatchServiceDirectoryScanner - Class in org.springframework.integration.file
Deprecated.
since 4.3 in favor of internal WatchService logic in the FileReadingMessageSource. Will be removed in Spring Integration 5.0.
WatchServiceDirectoryScanner(String) - Constructor for class org.springframework.integration.file.WatchServiceDirectoryScanner
Deprecated.
Construct an instance for the given directory.
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
 
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
 
WhiteListDeserializingConverter - Class in org.springframework.integration.support.converter
A Converter that delegates to a Deserializer to convert data in a byte array to an object.
WhiteListDeserializingConverter() - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter with default ObjectInputStream configuration, using the "latest user-defined ClassLoader".
WhiteListDeserializingConverter(ClassLoader) - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter for using an ObjectInputStream with the given ClassLoader.
WhiteListDeserializingConverter(Deserializer<Object>) - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter that delegates to the provided Deserializer.
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.
WireTapParser - Class in org.springframework.integration.config.xml
Parser for the <wire-tap> element.
WireTapParser() - Constructor for class org.springframework.integration.config.xml.WireTapParser
 
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) - 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
 
wrapConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
wrapExceptionIfNecessary(Message<?>, Exception) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
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
Writes the header, according to the header format.
writeInternal(Serializable, HttpOutputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
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
 
WWW_AUTHENTICATE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 

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
 
xmppConnection - Variable in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
xmppConnection - Variable in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
XmppConnectionFactoryBean - Class in org.springframework.integration.xmpp.config
This class configures an XMPPTCPConnection object.
XmppConnectionFactoryBean() - Constructor for class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
XmppConnectionFactoryBean(XMPPTCPConnectionConfiguration) - Constructor for class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
Deprecated.
since 4.2.5 in favor of XmppConnectionFactoryBean.setConnectionConfiguration(XMPPTCPConnectionConfiguration) to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
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 HeaderMapper 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

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
 
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