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

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
 
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
 
AbstractChannelAdapterParser - Class in org.springframework.integration.config.xml
Base parser for Channel Adapters.
AbstractChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
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.
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
 
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
 
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
 
AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
Abstract base class for HeaderMapper implementations.
AbstractHeaderMapper() - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper
 
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
 
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
 
AbstractJmsChannel - Class in org.springframework.integration.jms
 
AbstractJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.AbstractJmsChannel
 
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
 
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.
AbstractMessageChannel.ChannelInterceptorList() - Constructor for class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
AbstractMessageGroupStore - Class in org.springframework.integration.store
 
AbstractMessageGroupStore() - 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
 
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
 
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
 
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 java.lang.annotation.Annotation> - Class in org.springframework.integration.config.annotation
Base class for Method-level annotation post-processors.
AbstractMethodAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
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
 
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
 
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>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
AbstractRemoteFileOutboundGatewayParser - Class in org.springframework.integration.file.config
 
AbstractRemoteFileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
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
 
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
 
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
 
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
 
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
 
AbstractTcpConnection - Class in org.springframework.integration.ip.tcp.connection
Base class for TcpConnections.
AbstractTcpConnection(Socket, boolean, boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
AbstractTcpConnectionInterceptor - Class in org.springframework.integration.ip.tcp.connection
Base class for TcpConnectionIntercepters; passes all method calls through to the underlying TcpConnection.
AbstractTcpConnectionInterceptor() - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
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.RequestMessageCallback(WebServiceMessageCallback, Message<?>) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
 
AbstractWebServiceOutboundGateway.ResponseMessageExtractor - Class in org.springframework.integration.ws
 
AbstractWebServiceOutboundGateway.ResponseMessageExtractor() - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
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(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.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.locking.AbstractFileLockerFilter
 
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.PayloadTypeSelector
 
accept(Message<?>) - Method in class org.springframework.integration.selector.UnexpiredMessageSelector
 
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
Return true if the XPathExpression evaluates to true
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
Evaluate the payload and return true if the value returned by the XPathExpression matches the regex.
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Evaluate the payload and return true if the value returned by the XPathExpression is equal to the valueToTestFor.
accept(Message<?>) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
AcceptAllFileListFilter<F> - Class in org.springframework.integration.file.filters
Simple implementation of FileListFilter that always returns true.
AcceptAllFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptAllFileListFilter
 
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_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
 
ACK_ID - Static variable in class org.springframework.integration.ip.IpHeaders
 
add(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
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 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
 
addConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
addConstuctorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
Adds a constructor-arg to the provided bean definition builder with the value of the attribute whose name is provided if that attribute is defined in the given element.
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
 
addHostAndPortToConstructor(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Add a channel interceptor to the end of the list.
addMessage(Message<T>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
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
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Add a Message to the group with the provided group ID.
addMessageToGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
Store a message with an association to a group id.
addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
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
 
addPatternMapping(Pattern, ChannelAccessPolicy) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
addPortToConstructor(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
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.SourcePollingChannelAdapterFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
afterPropertiesSet() - Method in class org.springframework.integration.core.MessagingTemplate
 
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.synchronizer.AbstractInboundFileSynchronizer
 
afterPropertiesSet() - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
 
afterPropertiesSet() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
afterPropertiesSet() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Check mandatory properties (data source and incrementer).
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.resource.ResourceRetrievingMessageSource
 
afterPropertiesSet() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
afterPropertiesSet() - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
afterPropertiesSet() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
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<?>>) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
 
afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
afterSend(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
AggregatedXmlMessageValidationException - Exception in org.springframework.integration.xml
 
AggregatedXmlMessageValidationException(List<Throwable>) - Constructor for exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
aggregateHeaders(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
This default implementation simply returns all headers that have no conflicts among the group.
AggregateMessageDeliveryException - Exception in org.springframework.integration.dispatcher
An Exception that encapsulates an aggregated group of Exceptions for use by dispatchers that may try multiple handler invocations within a single dispatch operation.
AggregateMessageDeliveryException(Message<?>, String, List<? extends Exception>) - Constructor for exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
 
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
Evaluate the expression provided on the messages (a collection) in the group, and delegate to the MessagingTemplate to send downstream.
aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
AggregatingMessageHandler - Class in org.springframework.integration.aggregator
Aggregator specific implementation of AbstractCorrelatingMessageHandler.
AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
AggregatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
 
Aggregator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of aggregating messages.
AggregatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @Aggregator annotation.
AggregatorAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
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
 
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.
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.
AmqpHeaders - Class in org.springframework.integration.amqp
Pre-defined names and prefixes to be used for setting and/or retrieving AMQP MessageProperties from/to integration Message Headers.
AmqpHeaders() - Constructor for class org.springframework.integration.amqp.AmqpHeaders
 
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
 
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
 
AmqpInboundGatewayParser - Class in org.springframework.integration.amqp.config
Parser for the AMQP 'inbound-gateway' element.
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
 
APP_ID - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
append(double) - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
Add a new measurement to the series.
ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
An inbound Channel Adapter that 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_SEQUENCE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
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<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
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
 
AUTO_STARTUP - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
availablePermits() - Method in class org.springframework.integration.util.UpperBound
 

B

BCC - Static variable in class org.springframework.integration.mail.MailHeaders
 
BeanDefinitionRegisteringParser - Interface in org.springframework.integration.config.xml
Simple strategy interface for parsers that are responsible for parsing an element, creating a bean definition, and then registering the bean.
beanFactory - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
BeanFactoryChannelResolver - Class in org.springframework.integration.support.channel
ChannelResolver 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
 
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
 
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.
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
 
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 class org.springframework.integration.support.MessageBuilder
 
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
 
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.
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
 
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
 
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

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
 
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
 
CachingSessionFactory(SessionFactory<F>, int) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
 
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
 
canConvert(Class<?>, Class<?>) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
canConvert(TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
canRead(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
canRead(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
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.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
 
CC - Static variable in class org.springframework.integration.mail.MailHeaders
 
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.config.xml.AbstractIntegrationNamespaceHandler
 
ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
Interface to encapsulate ConfigAttributes for secured channel send and receive operations.
ChannelInterceptor - Interface in org.springframework.integration.channel
Interface for interceptors that are able to view and/or modify the Messages being sent-to and/or received-from a MessageChannel.
ChannelInterceptorAdapter - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor with no-op method implementations so that subclasses do not have to implement all of the interface's methods.
ChannelInterceptorAdapter() - Constructor for class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
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
 
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
 
ChannelResolutionException - Exception in org.springframework.integration.support.channel
Thrown by a ChannelResolver when it cannot resolve a channel name.
ChannelResolutionException(String) - Constructor for exception org.springframework.integration.support.channel.ChannelResolutionException
Create a new ChannelResolutionException.
ChannelResolutionException(String, Throwable) - Constructor for exception org.springframework.integration.support.channel.ChannelResolutionException
Create a new ChannelResolutionException.
channelResolver - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
ChannelResolver - Interface in org.springframework.integration.support.channel
Strategy for resolving a name to a MessageChannel.
ChannelSecurityInterceptor - Class in org.springframework.integration.security.channel
An AOP interceptor that enforces authorization for MessageChannel send and/or receive calls.
ChannelSecurityInterceptor(ChannelSecurityMetadataSource) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
ChannelSecurityInterceptorBeanPostProcessor - Class in org.springframework.integration.security.config
A BeanPostProcessor that proxies MessageChannels to apply a ChannelSecurityInterceptor.
ChannelSecurityInterceptorBeanPostProcessor(ChannelSecurityInterceptor) - 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
 
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
 
CHAT_THREAD_ID - Static variable in class org.springframework.integration.xmpp.XmppHeaders
Deprecated. 
CHAT_TO - Static variable in class org.springframework.integration.xmpp.XmppHeaders
Deprecated. 
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
 
checkClosure(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
Creates a default task executor if none was supplied.
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
Remove all Messages from this channel.
clear() - Method in class org.springframework.integration.history.MessageHistory
 
clear() - Method in class org.springframework.integration.MessageHeaders
Since MessageHeaders are immutable the call to this method will result in UnsupportedOperationException
clear() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Clear the resource bundle cache.
CLIENT_MODE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
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
 
close() - Method in interface org.springframework.integration.file.remote.session.Session
 
close() - Method in class org.springframework.integration.ftp.session.FtpSession
 
close() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Closes the server.
close() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
Closes this connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
close() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Closes the connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Closes this connection.
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
closeConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
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.
CLUSTER_ID - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
CollectionFilter<T> - Interface in org.springframework.integration.util
Base strategy for filtering out a subset of a Collection of elements.
command - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
COMMAND_GET - Static variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
COMMAND_LS - Static variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
COMMAND_MGET - Static variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
COMMAND_RM - Static variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
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() - Method in interface org.springframework.integration.store.MessageGroup
 
complete() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
completeGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
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
 
CompositeFileListFilter<F> - Class in org.springframework.integration.file.filters
Simple FileListFilter that predicates its matches against any of many 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
 
config - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
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) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, Class<?>, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Utility method to configure HeaderMapper for Inbound and Outbound channel adapters/gateway
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.
CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
 
CONNECTION_SEQ - Static variable in class org.springframework.integration.ip.IpHeaders
Deprecated.  
ConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
A factory used to create TcpConnection objects.
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
 
ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
 
ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
contains(Object) - Method in class org.springframework.integration.history.MessageHistory
 
containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
containsKey(Object) - Method in class org.springframework.integration.MessageHeaders
 
containsValue(Object) - Method in class org.springframework.integration.MessageHeaders
 
CONTENT_ENCODING - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
CONTENT_LENGTH - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
CONTENT_TYPE - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
CONTENT_TYPE - Static variable in class org.springframework.integration.mail.MailHeaders
 
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
 
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
 
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
 
convert(Object) - Method in class org.springframework.integration.util.UUIDConverter
Convert the input to a UUID using the convenience method UUIDConverter.getUUID(Object).
convertAndSend(T) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the default channel, converting the object to a message with a configured MessageConverter.
convertAndSend(MessageChannel, T) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the specified channel, converting the object to a message with a configured MessageConverter.
convertAndSend(String, T) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the specified channel, converting the object to a message with a configured MessageConverter.
convertAndSend(T, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the default channel, converting the object to a message with a configured MessageConverter.
convertAndSend(MessageChannel, T, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the specified channel, converting the object to a message with a configured MessageConverter.
convertAndSend(String, T, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given object to the specified channel, converting the object to a message with a configured MessageConverter.
convertAndSend(T) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertAndSend(MessageChannel, T) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertAndSend(String, T) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertAndSend(T, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertAndSend(MessageChannel, T, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertAndSend(String, T, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
converter - Variable in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
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.
convertSendAndReceive(Object) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the default channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(MessageChannel, Object) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the specified channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(String, Object) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the specified channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the default channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the specified channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.MessagingOperations
Send the given request object to the specified channel, converting the object to a message with a configured MessageConverter.
convertSendAndReceive(Object) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertSendAndReceive(MessageChannel, Object) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertSendAndReceive(String, Object) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
convertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.MessagingTemplate
 
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
 
convertValue(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
COOKIE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
copyHeaders(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.MessageBuilder
Copy the name-value pairs from the provided Map.
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.amqp.AmqpHeaders
 
CORRELATION_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
 
CORRELATION_ID - Static variable in class org.springframework.integration.MessageHeaders
 
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(Object) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Create a factory and set up the delegate which clients of the factory will see as its product.
CorrelationStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Create a factory and set up the delegate which clients of the factory will see as its product.
CqEventType - Enum in org.springframework.integration.gemfire.inbound
Enumeration of GemFire Continuous Query Event Types
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.
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.
createHandler() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
createHandler(Object, Method, T) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
Subclasses must implement this method to create the MessageHandler.
createHandler(Object, Method, Aggregator) - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
createHandler(Object, Method, Filter) - Method in class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
 
createHandler(Object, Method, Router) - Method in class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
 
createHandler(Object, Method, ServiceActivator) - Method in class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
createHandler(Object, Method, Splitter) - Method in class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
 
createHandler(Object, Method, Transformer) - Method in class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
 
createHandler() - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
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
 
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.ip.config.TcpConnectionFactoryFactoryBean
 
createInstance() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
createInstance() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
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.
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.
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
 
createTaskScheduler(int) - Static method in class org.springframework.integration.test.util.TestUtils
 
createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
 

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
 
decorate(Node, BeanDefinitionHolder, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
DEFAULT_CHARSET - Static variable in class org.springframework.integration.util.UUIDConverter
 
DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
DEFAULT_LONG_STRING_LENGTH - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
 
DEFAULT_MOVING_AVERAGE_WINDOW - Static variable in class org.springframework.integration.monitor.DirectChannelMetrics
 
DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
DEFAULT_REMOTE_WORKING_DIRECTORY - Static variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
DEFAULT_REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
DEFAULT_SEND_TIMEOUT - Static variable in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
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.
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
 
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.
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
 
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
 
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
 
DefaultLockRegistry - Class in org.springframework.integration.util
Default implementation of LockRegistry which uses Masked Hashcode algorithm to obtain locks.
DefaultLockRegistry() - Constructor for class org.springframework.integration.util.DefaultLockRegistry
Constructs a DefaultLockRegistry with the default mask 0xFF with 256 locks.
DefaultLockRegistry(int) - Constructor for class org.springframework.integration.util.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.
DefaultMessageSplitter - Class in org.springframework.integration.splitter
The default Message Splitter implementation.
DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
 
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
 
DefaultRouterParser - Class in org.springframework.integration.config.xml
Parser for the <router/> element.
DefaultRouterParser() - Constructor for class org.springframework.integration.config.xml.DefaultRouterParser
 
DefaultScriptVariableGenerator - Class in org.springframework.integration.scripting
 
DefaultScriptVariableGenerator() - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
 
DefaultScriptVariableGenerator(Map<String, Object>) - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
 
DefaultSftpSessionFactory - Class in org.springframework.integration.sftp.session
Factory for creating SftpSession instances.
DefaultSftpSessionFactory() - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
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
 
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 presence of a delay header on an inbound Message or a default delay value configured on this handler.
DelayHandler(long) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given default delay.
DelayHandler(long, TaskScheduler) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given default delay.
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.
DELIVERY_MODE - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
DELIVERY_TAG - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
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.ByteArrayCrLfSerializer
Reads the data in the inputstream to a byte[].
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.ByteArrayRawSerializer
 
deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
Reads the data in the inputstream to a byte[].
destroy() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
 
destroy() - Method in class org.springframework.integration.handler.DelayHandler
 
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.monitor.DirectChannelMetrics
 
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.store.MessageGroupStoreReaper
 
destroy() - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
destroyInstance(AbstractJmsChannel) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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
 
determineUrlsForHandler(String) - Method in class org.springframework.integration.http.inbound.UriPathHandlerMapping
 
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.
DirectChannelMetrics - Class in org.springframework.integration.monitor
Registers all message channels, and accumulates statistics about their performance.
DirectChannelMetrics(MessageChannel, String) - Constructor for class org.springframework.integration.monitor.DirectChannelMetrics
 
DirectMessageReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
This class handles support for receiving DMs (direct messages) using Twitter.
DirectMessageReceivingMessageSource(Twitter) - 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.
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
 
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
 
doExtractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
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
 
doInvoke(MethodInvocation, String, MessageChannel) - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
doInvoke(MethodInvocation, String, MessageChannel) - Method in class org.springframework.integration.monitor.PollableChannelMetrics
 
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
 
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
 
DomResultFactory - Class in org.springframework.integration.xml.result
 
DomResultFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.result.DomResultFactory
 
DomResultFactory() - 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.MessageHistoryParser
 
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, ParserContext, String) - Method in class org.springframework.integration.event.config.EventInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireCqInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
 
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, 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, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
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
 
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.xml.config.XPathRouterParser
 
doPoll() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
doPoll() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
doPoll() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
doPoll(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
doPoll() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
 
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.rmi.config.RmiInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
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.jmx.AttributePollingMessageSource
Retrieves the JMX attribute value.
doReceive() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
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
 
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(Message<?>, long) - Method in class org.springframework.integration.jms.AbstractJmsChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
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.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.event.inbound.ApplicationEventListeningMessageProducer
 
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
 
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.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.monitor.IntegrationMBeanExporter
 
doStart() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
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.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.event.inbound.ApplicationEventListeningMessageProducer
 
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.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.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.monitor.IntegrationMBeanExporter
 
doStop() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
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.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.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
 
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
 
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
 

E

EnricherParser - Class in org.springframework.integration.config.xml
Parser for the 'enricher' element.
EnricherParser() - Constructor for class org.springframework.integration.config.xml.EnricherParser
 
entrySet() - Method in class org.springframework.integration.MessageHeaders
 
equals(Object) - Method in class org.springframework.integration.message.GenericMessage
 
equals(Object) - Method in class org.springframework.integration.MessageHeaders
 
ERROR_CHANNEL - Static variable in class org.springframework.integration.MessageHeaders
 
ERROR_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
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
 
ErrorMessage - Class in org.springframework.integration.message
A message implementation that accepts a Throwable payload.
ErrorMessage(Throwable) - Constructor for class org.springframework.integration.message.ErrorMessage
 
ErrorMessage(Throwable, Map<String, Object>) - Constructor for class org.springframework.integration.message.ErrorMessage
 
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
 
escapeRegexSpecials(String) - Static method in class org.springframework.integration.ip.util.RegexUtils
Escapes (precedes with \) any characters in the parameter in the set

.$[]^*+{}()\?|

Used to escape a string that is used as a regular expression pattern, to remove the special meaning of these characters.
ETX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
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
 
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.
exceptionIterator() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
Returns an Iterator for the aggregated Exceptions.
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
exchange(Message<?>) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
execute(MessageGroupStore, MessageGroup) - Method in interface org.springframework.integration.store.MessageGroupCallback
 
execute(Runnable) - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Subclasses must implement this method.
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.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.
executeUpdateQuery(Object, boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
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.
exists(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
exists(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
EXPIRATION - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
EXPIRATION_DATE - Static variable in class org.springframework.integration.MessageHeaders
 
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.
ExponentialMovingAverage - Class in org.springframework.integration.monitor
Cumulative statistics for a series of real numbers with higher weight given to recent data but without storing any history.
ExponentialMovingAverage(int) - Constructor for class org.springframework.integration.monitor.ExponentialMovingAverage
Create a moving average accumulator with decay lapse window provided.
ExponentialMovingAverageRate - Class in org.springframework.integration.monitor
Cumulative statistics for an event rate with higher weight given to recent data but without storing any history.
ExponentialMovingAverageRate(double, double, int) - Constructor for class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
ExponentialMovingAverageRatio - Class in org.springframework.integration.monitor
Cumulative statistics for success ratio with higher weight given to recent data but without storing any history.
ExponentialMovingAverageRatio(double, int) - Constructor for class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
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
 
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
 
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
 
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
 
ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that evaluates an expression.
ExpressionEvaluatingReleaseStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
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
 
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
 
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
 
ExpressionSource - Interface in org.springframework.integration.expression
Strategy interface for retrieving Expressions.
ExtendedSession<T> - Interface in org.springframework.integration.file.remote.session
Temporary extension to Session to avoid a breaking change in a point release - merge with Session in 2.2.
extractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
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(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
extractStandardHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractStandardHeaders(Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
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
 
extractUserDefinedHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractUserDefinedHeaders(Message) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 

F

failure() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
Add a new event with failed outcome.
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) - 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, 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.
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.
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.
FILENAME - Static variable in class org.springframework.integration.file.FileHeaders
 
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
 
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
 
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

The size of the queue used should be large enough to hold all the files in the input directory in order to sort all of them, so restricting the size of the queue is mutually exclusive with ordering.

FileReadingMessageSourceFactoryBean - Class in org.springframework.integration.file.config
 
FileReadingMessageSourceFactoryBean() - Constructor for class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
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
 
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
 
FileWritingMessageHandlerFactoryBean - Class in org.springframework.integration.file.config
Factory bean used to create FileWritingMessageHandlers.
FileWritingMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
Filter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of playing the role of a Message Filter.
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(ListableBeanFactory) - 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.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(F[]) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
filterFiles(F[]) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
FilterParser - Class in org.springframework.integration.config.xml
Parser for the <filter/> element.
FilterParser() - Constructor for class org.springframework.integration.config.xml.FilterParser
 
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
 
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
 
folderOpenMode - Variable in class org.springframework.integration.mail.AbstractMailReceiver
 
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, T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
fromHeadersToReply(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Maps headers from a Spring Integration MessageHeaders instance to the target instance matching on the set of REPLY headers (if different).
fromHeadersToReply(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
 
fromHeadersToRequest(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Maps headers from a Spring Integration MessageHeaders instance to the target instance matching on the set of REQUEST headers (if different).
fromHeadersToRequest(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
 
fromMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
fromMessage(Message<?>) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
Raw byte[] from message, possibly with a length field up front.
fromMessage(Message<?>) - Method in class org.springframework.integration.json.JsonOutboundMessageMapper
 
fromMessage(Message<?>) - Method in interface org.springframework.integration.mapping.OutboundMessageMapper
 
fromMessage(Message<P>) - Method in interface org.springframework.integration.support.converter.MessageConverter
 
fromMessage(Message<P>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
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.
fromSoapHeaders(MessageContext, MessageBuilder<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
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
 
FtpNamespaceHandler - Class in org.springframework.integration.ftp.config
Provides namespace support for using FTP

This is *heavily* influenced by the good work done by Iwein before.

FtpNamespaceHandler() - Constructor for class org.springframework.integration.ftp.config.FtpNamespaceHandler
 
FtpOutboundGateway - Class in org.springframework.integration.ftp.gateway
Outbound Gateway for performing remote file operations via FTP/FTPS.
FtpOutboundGateway(SessionFactory<FTPFile>, String, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
FtpOutboundGatewayParser - Class in org.springframework.integration.ftp.config
 
FtpOutboundGatewayParser() - Constructor for class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
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
 
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
 

G

Gateway - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of mapping its parameters to a message or message payload.
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
 
GemfireMessageStore - Class in org.springframework.integration.gemfire.store
Gemfire implementation of the key/value style MessageStore and MessageGroupStore
GemfireMessageStore(Cache) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
 
GemfireOutboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
 
GemfireOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireOutboundChannelAdapterParser
 
generateFileName(Message<?>) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.file.FileNameGenerator
 
generateId() - Method in interface org.springframework.integration.MessageHeaders.IdGenerator
 
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
 
GenericMessage<T> - Class in org.springframework.integration.message
Base Message class defining common properties such as id, payload, and headers.
GenericMessage(T) - Constructor for class org.springframework.integration.message.GenericMessage
Create a new message with the given payload.
GenericMessage(T, Map<String, Object>) - Constructor for class org.springframework.integration.message.GenericMessage
Create a new message with the given payload.
get(Session<F>, String, String, boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Copy a remote file to the configured local directory.
get(int) - Method in class org.springframework.integration.history.MessageHistory
 
get(Object, Class<T>) - Method in class org.springframework.integration.MessageHeaders
 
get(Object) - Method in class org.springframework.integration.MessageHeaders
 
get(String) - Method in interface org.springframework.integration.store.MetadataStore
Reads a value for the given key from this MetadataStore.
get(String) - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
get(String) - Method in class org.springframework.integration.store.SimpleMetadataStore
 
getAckPort() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getActiveCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getActiveCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getActiveHandlerCount() - 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
 
getAggregatedExceptions() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
getAllConfigAttributes() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getAttributes(Object) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getBeanClass(Element) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.GatewayParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
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.groovy.config.GroovyScriptParser
 
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.scripting.config.AbstractScriptParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
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
 
getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
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.context.IntegrationObjectSupport
 
getBytes() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
getChannel() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getChannelCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelErrorRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Subclasses must implement this method to return the channel keys.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter
Selects the most appropriate channel name matching channel identifiers which are the fully qualified class names encountered while traversing the payload type hierarchy.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.xml.router.XPathRouter
 
getChannelMappings() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Returns an unmodifiable version of the channel mappings.
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
 
getChannelReceiveCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelSendRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getCode() - Method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
Get the numerical representation of the JDBC Type enum.
getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Will return the name of this component identified by IntegrationObjectSupport.componentName field.
getComponentName() - Method in interface org.springframework.integration.context.NamedComponent
 
getComponentName() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
getComponentType() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
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 interface org.springframework.integration.context.NamedComponent
 
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.filter.MessageFilter
 
getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
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.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.JdbcPollingChannelAdapter
 
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.NotificationListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
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.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
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.ws.AbstractWebServiceInboundGateway
 
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.XsltPayloadTransformer
 
getComponentType() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
getComponentType() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
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
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Obtains a connection - if AbstractConnectionFactory.setSingleUse(boolean) was called with true, a new connection is returned; otherwise a single connection is reused for all requests while the connection remains open.
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Not supported because the factory manages multiple connections and this method cannot discriminate.
getConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ConnectionFactory
 
getConnection() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getConnectionId() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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
 
getContentType() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getConversionService(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return the ConversionService bean whose name is "integrationConversionService" if available.
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getConverter() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
getCorrelationId() - Method in class org.springframework.integration.MessageHeaders
 
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
 
getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getCount() - Method in class org.springframework.integration.monitor.Statistics
 
getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return the default PollerMetadata bean if available.
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getDeserializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getDestinationAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
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.monitor.LifecycleMessageHandlerMetrics
 
getDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return the MessageChannel bean whose name is "errorChannel".
getErrorChannel() - Method in class org.springframework.integration.MessageHeaders
 
getErrorCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getErrorCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getErrorCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getErrorHandler() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getErrorRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getErrorRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getEvaluationContext() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
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
 
getExpirationDate() - Method in class org.springframework.integration.MessageHeaders
 
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
 
getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
 
getFailedMessage() - Method in exception org.springframework.integration.MessagingException
 
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(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(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(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
 
getFiles(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
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
 
getGroupId() - Method in interface org.springframework.integration.store.MessageGroup
 
getGroupId() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getGroupId() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getHandleCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getHandleCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getHandleCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
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
 
getHandlerIterator(Message<?>, List<MessageHandler>) - Method in interface org.springframework.integration.dispatcher.LoadBalancingStrategy
 
getHandlerIterator(Message<?>, List<MessageHandler>) - Method in class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
Returns an iterator that starts at a new point in the list 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.
getHandlerNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Returns a copied, unmodifiable List of this dispatcher's handlers.
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
 
getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getHeaders() - Method in class org.springframework.integration.message.GenericMessage
 
getHeaders() - Method in interface org.springframework.integration.Message
 
getHost() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getHostAddress() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getHostName() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getHostName() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getHostName() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getId() - Method in class org.springframework.integration.MessageHeaders
 
getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
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
 
getInputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getInputStream() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
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
Exposes the interceptor list for subclasses.
getLastMessage() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
 
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
 
getLastRead() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getLastReleasedMessageSequenceNumber() - Method in interface org.springframework.integration.store.MessageGroup
Returns the sequenceNumber of the last released message.
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getListener() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getLocalAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
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
 
getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getMax() - Method in class org.springframework.integration.monitor.Statistics
 
getMaxDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getMaxDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getMaxDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
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
 
getMaxSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMaxSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getMean() - Method in class org.springframework.integration.monitor.Statistics
 
getMeanDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getMeanDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getMeanDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMeanErrorRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMeanErrorRatio() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMeanSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMeanSendRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getMessage() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
getMessage() - Method in class org.springframework.integration.event.core.MessagingEvent
 
getMessage(UUID) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessage() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
Return the Message with the given id, or null if no Message with that id exists in the MessageStore.
getMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessage() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getMessageChannel() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMessageCount() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessageCount() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageCount() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
getMessageCount() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
 
getMessageCount() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
getMessageCount() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageCount() - Method in interface org.springframework.integration.store.MessageStore
Optional attribute giving the number of messages in the store.
getMessageCount() - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
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.
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
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.MessageGroupStore
Return all Messages currently in the MessageStore that were stored using MessageGroupStore.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.store.AbstractMessageGroupStore
 
getMessageGroupCount() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of message groups.
getMessageHandler() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
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
 
getMessageSource() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
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.handler.AbstractReplyProducingMessageHandler
Provides access to the MessagingTemplate for subclasses.
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
Return the MetadataStore bean whose name is "metadataStore".
getMethodInvocation() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getMin() - Method in class org.springframework.integration.monitor.Statistics
 
getMinDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getMinDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getMinDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getMinSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getMinSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getModified() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getModified(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getModified(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getModified() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getModified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
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)
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.monitor.DirectChannelMetrics
 
getName() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getName() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
getName() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getName() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
 
getName() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getName() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
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
 
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.ReleaseStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.file.remote.session.SessionFactoryFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
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.ReleaseStrategyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.remote.session.SessionFactoryFactoryBean
 
getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
getObjectType() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
getObjectType() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
getObjectType() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getOne() - Method in interface org.springframework.integration.store.MessageGroup
 
getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
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.handler.AbstractMessageHandler
 
getOrder() - Method in class org.springframework.integration.handler.DelayHandler
 
getOrder() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getOriginalFilename() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getOrMakeConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
getOrMakeConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
getOrMakeConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
getOutputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getParameterMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getPatterns() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
getPayload() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
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.TcpNetConnection
 
getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getPayload() - Method in class org.springframework.integration.message.GenericMessage
 
getPayload() - Method in interface org.springframework.integration.Message
 
getPayload() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
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
 
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.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.TcpOutboundGateway
 
getPhase() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
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.monitor.IntegrationMBeanExporter
 
getPhase() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
getPhase() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
getPhase() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getPoolSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.AbstractTcpConnectionInterceptor
 
getPort() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getPriority() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getPriority() - Method in class org.springframework.integration.MessageHeaders
 
getProcedureParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
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
 
getQuery(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Replace patterns in the input to produce a valid SQL query.
getQueuedMessageCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getQueueSize() - Method in class org.springframework.integration.channel.QueueChannel
 
getQueueSize() - Method in class org.springframework.integration.monitor.QueueChannelMetrics
 
getReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getReceiveCount() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
 
getReceiveErrorCount() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
 
getReceiveTimeout() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getReceiveTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getRemainingCapacity() - Method in class org.springframework.integration.monitor.QueueChannelMetrics
 
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
 
getReplyChannel() - Method in class org.springframework.integration.MessageHeaders
 
getRequiredConversionService() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return the TaskScheduler bean whose name is "taskScheduler".
getResponseValidator() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
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
 
getReturningResultsetBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
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
 
getScheduler() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
getScheduler() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getScheduler() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
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
 
getScriptSourceClassName() - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
getScriptSourceClassName() - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
 
getScriptSourceClassName() - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
getSecureObjectClass() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
getSendCount() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getSendCount() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getSendErrorCount() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getSendErrorCount() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getSendRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getSequenceNumber() - Method in class org.springframework.integration.MessageHeaders
 
getSequenceSize() - Method in class org.springframework.integration.MessageHeaders
 
getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getSerializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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
 
getSession() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
 
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
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
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
 
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
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.udp.UnicastSendingMessageHandler
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSource() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getSource() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
getSource() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getSource() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
 
getSource() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getSource() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
getSourceMessageCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSqlParameterDefinitionBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getStandardDeviation() - Method in class org.springframework.integration.monitor.Statistics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getStandardDeviationSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getStandardHeaderPrefix() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
getStandardHeaderPrefix() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Returns the list of standard REPLY headers.
getStandardHeaderPrefix() - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
getStandardHeaderPrefix() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
getStandardReplyHeaderNames() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
getStandardReplyHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Returns the list of standard REQUEST headers.
getStandardReplyHeaderNames() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
getStandardRequestHeaderNames() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
 
getStandardRequestHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Returns the PREFIX used by standard headers (if any)
getStandardRequestHeaderNames() - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
getStandardRequestHeaderNames() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getStoredProcedureName() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
 
getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
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.scheduling.PollerMetadata
 
getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return the TaskScheduler bean whose name is "taskScheduler" if available.
getTaskScheduler() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
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.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.AbstractTcpConnectionInterceptor
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.monitor.ExponentialMovingAverageRate
 
getTimeSinceLastMeasurement() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
getTimeSinceLastSend() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
getTimeSinceLastSend() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getTimestamp() - Method in class org.springframework.integration.MessageHeaders
 
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
 
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.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
 
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
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.jdbc.storedproc.ProcedureParameter
 
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
 
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
 
getWebServiceTemplate() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
getXPathExpresion() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
Parser for 'channel-interceptor' elements.
GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
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
 
GroovyCommandMessageProcessor - Class in org.springframework.integration.groovy
 
GroovyCommandMessageProcessor() - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Creates a GroovyCommandMessageProcessor that will use the DefaultScriptVariableGenerator.
GroovyCommandMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Creates a GroovyCommandMessageProcessor that will use the provided ScriptVariableGenerator.
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
 
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
 
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
 
GroovyScriptParser() - Constructor for class org.springframework.integration.groovy.config.GroovyScriptParser
 

H

handleError(Throwable) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
handleMessage(Message<?>) - Method in interface org.springframework.integration.core.MessageHandler
Handles the message if possible.
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.DelayHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.test.support.AbstractResponseValidator
handle the message
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.router.AbstractMessageRouter
 
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.xmpp.outbound.ChatMessageSendingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
handleNotification(Notification, Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Notification handling method implementation.
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.amqp.outbound.AmqpOutboundEndpoint
 
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.filter.MessageFilter
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Subclasses must implement this method to handle the request Message.
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.BridgeHandler
 
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.rmi.RmiOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
handlerExpecting(Matcher<Message>) - Static method in class org.springframework.integration.test.util.TestUtils
 
harvestClosedConnections() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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
 
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.message.GenericMessage
 
hashCode() - Method in class org.springframework.integration.MessageHeaders
 
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
 
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.AbstractTcpConnectionInterceptor
 
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
 
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
Annotation indicating that a method parameter's value should be retrieved from the message headers.
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
 
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 HeaderEnricher.HeaderValueMessageProcessor<?>>) - Constructor for class org.springframework.integration.transformer.HeaderEnricher
Create a HeaderEnricher with the given map of headers.
HeaderEnricher.HeaderValueMessageProcessor<T> - Interface in org.springframework.integration.transformer
 
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?
Headers - Annotation Type in org.springframework.integration.annotation
Annotation indicating that a method parameter's value should be mapped to or from the message headers.
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
 
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
 
HOSTNAME - Static variable in class org.springframework.integration.ip.IpHeaders
 
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
 
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
 
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(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
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
 
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.MessageHeaders
The key for the Message ID.
IdGeneratorConfigurer - Class in org.springframework.integration.config
 
IdGeneratorConfigurer() - Constructor for class org.springframework.integration.config.IdGeneratorConfigurer
 
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
 
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
 
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
 
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.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.
increment() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
Add a new event to the series.
incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
incrementAndGetConnectionSequence() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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() - 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.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.mail.config.MailNamespaceHandler
 
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.stream.config.StreamNamespaceHandler
 
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.ws.config.WsNamespaceHandler
 
init() - Method in class org.springframework.integration.xml.config.IntegrationXmlNamespaceHandler
 
init() - Method in class org.springframework.integration.xmpp.config.XmppNamespaceHandler
 
initializeConnection(TcpConnection, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Transfers attributes such as (de)serializers, singleUse etc to a new connection.
initializeConnection(TcpConnection, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Transfers attributes such as (de)serializer, singleUse 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
 
initializeQueue(AmqpAdmin, String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
 
initializeQueue(AmqpAdmin, String) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
injectPropertyWithAdapter(String, String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
 
INTEGRATION_CONVERSION_SERVICE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
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
 
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
 
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
 
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
 
IntegrationSecurityNamespaceHandler - Class in org.springframework.integration.security.config
Namespace handler for the security namespace.
IntegrationSecurityNamespaceHandler() - Constructor for class org.springframework.integration.security.config.IntegrationSecurityNamespaceHandler
 
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
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
invoke(MethodInvocation) - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
invoke(MethodInvocation) - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
invoke(MethodInvocation) - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
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
 
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.
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
 
isAcknowledge() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
isActive() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
isActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.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.TcpOutboundGateway
 
isAutoStartup() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
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.monitor.IntegrationMBeanExporter
 
isAutoStartup() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
isAutoStartup() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isAutoStartup() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
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
 
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
 
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
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.xml.GatewayParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
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.history.MessageHistory
 
isEmpty() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
isEmpty() - Method in class org.springframework.integration.MessageHeaders
 
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
 
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
 
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
 
isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isModified() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
isOpen() - Method in interface org.springframework.integration.file.remote.session.Session
 
isOpen() - Method in class org.springframework.integration.ftp.session.FtpSession
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
isOpen() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
isOverwrite() - Method in interface org.springframework.integration.transformer.HeaderEnricher.HeaderValueMessageProcessor
 
isReceive() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
isRequiresReply() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
isRunning() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
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.annotation.MessagingAnnotationPostProcessor
 
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.history.MessageHistoryConfigurer
 
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.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.SubscribableJmsChannel
 
isRunning() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
isRunning() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
isRunning() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
isRunning() - Method in class org.springframework.integration.monitor.ManagedEndpoint
 
isRunning() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
isRunning() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isRunning() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
isRunning() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
isSend() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
isServer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
isServer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
isServer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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.
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.ReleaseStrategyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.file.remote.session.SessionFactoryFactoryBean
 
isSingleton() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
isSingleUse() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
isTimeoutOnIdle() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
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
 
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.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
Returns the iterator of currently accumulated MessageGroups
iterator() - Method in class org.springframework.integration.store.SimpleMessageStore
 

J

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
Convenient constructor for configuration use.
JdbcMessageStore(DataSource) - 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
Parser for JdbcPollingChannelAdapter.
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.
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 - Interface in org.springframework.integration.jms
Strategy interface for mapping integration Message headers to an outbound JMS Message (e.g.
JmsHeaders - Class in org.springframework.integration.jms
Pre-defined names and prefixes to be used for setting and/or retrieving JMS attributes from/to integration Message Headers.
JmsHeaders() - Constructor for class org.springframework.integration.jms.JmsHeaders
 
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
 
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
 
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
 
JmxHeaders - Class in org.springframework.integration.jmx
Constants for JMX related Message Header keys.
JmxHeaders() - Constructor for class org.springframework.integration.jmx.JmxHeaders
 
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
 
JsonInboundMessageMapper - Class in org.springframework.integration.json
InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.
JsonInboundMessageMapper(Class<?>) - Constructor for class org.springframework.integration.json.JsonInboundMessageMapper
 
JsonInboundMessageMapper(TypeReference<?>) - Constructor for class org.springframework.integration.json.JsonInboundMessageMapper
 
JsonOutboundMessageMapper - Class in org.springframework.integration.json
OutboundMessageMapper implementation the converts a Message to a JSON string representation.
JsonOutboundMessageMapper() - Constructor for class org.springframework.integration.json.JsonOutboundMessageMapper
 
JsonToObjectTransformer<T> - Class in org.springframework.integration.json
Transformer implementation that converts a JSON string payload into an instance of the provided target Class.
JsonToObjectTransformer(Class<T>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<T>, ObjectMapper) - 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

keySet() - Method in class org.springframework.integration.MessageHeaders
 

L

lastIndexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
LifecycleMessageHandlerMetrics - Class in org.springframework.integration.monitor
A MessageHandlerMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageHandlerMetrics(Lifecycle, MessageHandlerMetrics) - Constructor for class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
LifecycleMessageSourceMetrics - Class in org.springframework.integration.monitor
A MessageSourceMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageSourceMetrics(Lifecycle, MessageSourceMetrics) - Constructor for class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
lifecycleMonitor - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
list(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
list(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
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
 
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
 
listNames(String) - Method in interface org.springframework.integration.file.remote.session.ExtendedSession
Returns an array of Strings containing just the names of the remote files at path.
listNames(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
LoadBalancingStrategy - Interface in org.springframework.integration.dispatcher
Strategy for determining the iteration order of a MessageHandler list.
locateComponentInHistory(MessageHistory, String, int) - Static method in class org.springframework.integration.test.util.TestUtils
 
LOCATION_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
 
lock(File) - Method in interface org.springframework.integration.file.FileLocker
Tries to lock the given file and returns true if it was successful, false otherwise.
lock(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
Tries to lock the given file and returns true if it was successful, false otherwise.
LockRegistry - Interface in org.springframework.integration.util
Strategy for maintaining a registry of shared locks
logger - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
logger - Variable in class org.springframework.integration.context.IntegrationObjectSupport
Logger that is available to subclasses
logger - Variable in class org.springframework.integration.core.MessagingTemplate
 
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.ip.tcp.connection.AbstractTcpConnection
 
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.monitor.DirectChannelMetrics
 
logger - Variable in class org.springframework.integration.store.AbstractMessageGroupStore
 
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' property.
LoggingHandler(String) - Constructor for class org.springframework.integration.handler.LoggingHandler
Create a LoggingHandler with the given log level (case-insensitive).
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

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.
MailHeaders() - Constructor for class org.springframework.integration.mail.MailHeaders
 
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
 
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(JavaMailSender) - Constructor for class org.springframework.integration.mail.MailSendingMessageHandler
Create a MailSendingMessageConsumer.
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
 
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
 
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
 
MappingMessageRouterManagement - Interface in org.springframework.integration.router
 
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
 
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) - 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.
MAX_MESSAGES_UNBOUNDED - Static variable in class org.springframework.integration.scheduling.PollerMetadata
 
maxMessageSize - Variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
 
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
 
MentionsReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
Receives Message Tweets
MentionsReceivingMessageSource(Twitter) - Constructor for class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
 
Message<T> - Interface in org.springframework.integration
The central interface that any Message type must implement.
MESSAGE_COUNT - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
MESSAGE_GROUP_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MESSAGE_ID - Static variable in class org.springframework.integration.amqp.AmqpHeaders
 
MESSAGE_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
 
MESSAGE_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MessageBuilder<T> - Class in org.springframework.integration.support
 
MessageChannel - Interface in org.springframework.integration
Base channel interface defining common behavior for sending messages.
MessageChannelMetrics - Interface in org.springframework.integration.monitor
Interface for all message channel monitors containing accessors for various useful metrics that are generic for all channel types.
MessageConversionException - Exception in org.springframework.integration.support.converter
 
MessageConversionException(String, Throwable) - Constructor for exception org.springframework.integration.support.converter.MessageConversionException
 
MessageConversionException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.support.converter.MessageConversionException
 
MessageConverter - Interface in org.springframework.integration.support.converter
 
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).
MessageDeliveryException - Exception in org.springframework.integration
Exception that indicates an error occurred during message delivery.
MessageDeliveryException(String) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDeliveryException(Message<?>) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDeliveryException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDeliveryException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
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
 
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.
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.
MessageGroupCallback - Interface in org.springframework.integration.store
 
MessageGroupMetadata - Class in org.springframework.integration.store
Immutable Value Object holding metadata about a MessageGroup.
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(MessageGroupStore, Object) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(MessageGroupStore, Object, int) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(MessageGroupStore, Object, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(MessageGroupStore, 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.mongodb.store.MongoDbMessageStore
 
messageGroupSize(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
messageGroupSize(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Returns the size of this MessageGroup
messageGroupSize(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
MessageGroupStore - Interface in org.springframework.integration.store
Interface for storage operations on groups of messages linked by a group id.
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
 
MessageHandler - Interface in org.springframework.integration.core
Base interface for any component that handles Messages.
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.monitor
 
MessageHandlingException - Exception in org.springframework.integration
Exception that indicates an error occurred during message handling.
MessageHandlingException(Message<?>) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHandlingException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHandlingException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHandlingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHeaders - Class in org.springframework.integration
The headers for a Message.
IMPORTANT: MessageHeaders are immutable.
MessageHeaders(Map<String, Object>) - Constructor for class org.springframework.integration.MessageHeaders
 
MessageHeaders.IdGenerator - Interface in org.springframework.integration
 
MessageHistory - Class in org.springframework.integration.history
 
MessageHistory.Entry - Class in org.springframework.integration.history
Inner class for each Entry in the history.
MessageHistory.Entry() - Constructor for class org.springframework.integration.history.MessageHistory.Entry
 
MessageHistoryConfigurer - Class in org.springframework.integration.history
 
MessageHistoryConfigurer() - Constructor for class org.springframework.integration.history.MessageHistoryConfigurer
 
MessageHistoryParser - Class in org.springframework.integration.config.xml
 
MessageHistoryParser() - Constructor for class org.springframework.integration.config.xml.MessageHistoryParser
 
messageIdIterator() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
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
 
MessagePostProcessor - Interface in org.springframework.integration.core
To be used with MessagingTemplate's send method that converts an object to a message.
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.
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(ChannelResolver) - 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<?>) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRejectedException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRejectedException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageRejectedException
 
messages - Variable in class org.springframework.integration.store.SimpleMessageGroup
 
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
 
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.monitor
 
messageStore - Variable in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
MessageStore - Interface in org.springframework.integr