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
 
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() - 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
 
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
 
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
 
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) - 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
 
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
 
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
 
AbstractRemotingOutboundGateway - Class in org.springframework.integration.gateway
Deprecated. as of 2.0. Will be removed in 2.1.
AbstractRemotingOutboundGateway(String) - Constructor for class org.springframework.integration.gateway.AbstractRemotingOutboundGateway
Deprecated.  
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
 
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
 
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 - 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
 
AbstractWebServiceOutboundGateway - Class in org.springframework.integration.ws
Base class for outbound Web Service-invoking Messaging Gateways.
AbstractWebServiceOutboundGateway(DestinationProvider, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
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.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
 
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
 
ackControl - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
ackCounter - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
acknowledge - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
ackPort - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
ackTimeout - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
active - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
active - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
active - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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 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 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.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.jms.ChannelPublishingJmsMessageListener
 
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
 
afterPropertiesSet() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
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 unmarked 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
 
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.
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
 
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
 
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
 

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

CachingSessionFactory - 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) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
 
CachingSessionFactory(SessionFactory, 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 unmarked 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
 
ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
Interface to encapsulate ConfigAttributes for secured channel send and receive operations.
channelIdentifierMap - Variable in class org.springframework.integration.router.AbstractMessageRouter
 
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
 
CHAT_TO - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
ChatMessageInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for the XMPP 'inbound-channel-adapter' element.
ChatMessageInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
 
ChatMessageListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
This component logs in as a user and forwards any messages to that user on to downstream components.
ChatMessageListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
ChatMessageListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
 
ChatMessageOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for the XMPP 'outbound-channel-adapter' element
ChatMessageOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
 
ChatMessageSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
MessageHandler that sends an XMPP Chat Message.
ChatMessageSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
ChatMessageSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
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
clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Clear the resource bundle cache.
clientConnectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
clientConnectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
clientMode - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
close() - Method in interface org.springframework.integration.file.remote.session.Session
 
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
 
close() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
Close the underlying socket and prepare to establish a new socket on the next write.
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.
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.
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
 
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 - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
 
CONNECTION_SEQ - Static variable in class org.springframework.integration.ip.IpHeaders
 
ConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
A factory used to create TcpConnection objects.
connectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
connectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
connectionId - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
connections - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
connections - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
connections - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
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_TYPE - Static variable in class org.springframework.integration.mail.MailHeaders
 
ControlBusParser - Class in org.springframework.integration.config.xml
 
ControlBusParser() - Constructor for class org.springframework.integration.config.xml.ControlBusParser
 
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
 
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
 
convertToDocument(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
convertToDocument(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
 
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
 
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
 
CorrelatingMessageHandler - Class in org.springframework.integration.aggregator
Message handler that holds a buffer of correlated messages in a MessageStore.
CorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
CorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
CorrelatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
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.
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, ideally a javax.jms.QueueConnection.
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.
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.groovy.config.GroovyControlBusFactoryBean
 
createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
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.
createProxy(String) - Method in class org.springframework.integration.gateway.AbstractRemotingOutboundGateway
Deprecated. Subclasses must implement this method.
createProxy(String) - Method in class org.springframework.integration.httpinvoker.HttpInvokerOutboundGateway
Deprecated.  
createProxy(String) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
 
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
 
createSession(Connection) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Create a new JMS Session for this JMS gateway, ideally a javax.jms.QueueSession.
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_POOL_SIZE - Static variable in class org.springframework.integration.file.remote.session.CachingSessionFactory
 
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.CorrelatingMessageHandler
 
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
 
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
 
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
 
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
 
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.
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[].
deserializer - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
deserializer - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
deserializer - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
destinationAddress - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
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.store.MessageGroupStoreReaper
 
destroy() - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
destroyInstance(AbstractJmsChannel) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
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(TwitterOperations) - 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(TwitterOperations) - 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
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
doHandle(Object, 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
 
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(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, BeanDefinitionBuilder) - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
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, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
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, BeanDefinitionBuilder) - 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
 
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.
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
 
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.ip.AbstractInternetProtocolReceivingChannelAdapter
 
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.xmpp.inbound.ChatMessageListeningEndpoint
 
doStart() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
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.ip.AbstractInternetProtocolReceivingChannelAdapter
 
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.xmpp.inbound.ChatMessageListeningEndpoint
 
doStop() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
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
 
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

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
 
exceptionIterator() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
Returns an Iterator for the aggregated Exceptions.
exchange(Message<?>) - Method in class org.springframework.integration.gateway.RemotingInboundGatewaySupport
Deprecated.  
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
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.
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
 
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
 
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.

F

failure() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
Add a new event with failed outcome.
fatalException - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
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
 
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 - Class in org.springframework.integration.file.remote.handler
A MessageHandler implementation that transfers files to a remote server.
FileTransferringMessageHandler(SessionFactory) - 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
 
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(List<Method>) - Method in class org.springframework.integration.util.AnnotatedMethodFilter
 
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.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
 
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
 
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
 
fromHeaders(MessageHeaders, SoapHeader) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
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.
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) - 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
 
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
 
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
 
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(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
 
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.httpinvoker.config.HttpInvokerInboundGatewayParser
Deprecated.  
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.jmx.config.NotificationListeningChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
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.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
 
getChannelIdentifiers(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
Subclasses must implement this method to return the channel identifiers.
getChannelIdentifiers(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
getChannelIdentifiers(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
 
getChannelIdentifiers(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.
getChannelIdentifiers(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter
 
getChannelIdentifiers(Message<?>) - Method in class org.springframework.integration.xml.router.XPathRouter
 
getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
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
 
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
 
getComponentName() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
getComponentType() - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
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.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.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.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.MarshallingWebServiceInboundGateway
 
getComponentType() - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
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.AbstractServerConnectionFactory
Not supported because the factory manages multiple connections and this method cannot discriminate.
getConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ConnectionFactory
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
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.TcpNioClientConnectionFactory
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.TcpSendingMessageHandler
 
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
 
getConnectionSeq() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
getConnectionSeq() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getConnectionSeq() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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
 
getCreatedAt() - Method in class org.springframework.integration.twitter.core.Tweet
 
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.AbstractTcpConnection
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getDeserializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getDirectMessages() - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getDirectMessages(long) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getDirectMessages() - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
getDirectMessages(long) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
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
 
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.
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
 
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(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.inbound.FtpInboundFileSynchronizer
 
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.inbound.SftpInboundFileSynchronizer
 
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
 
getFromUser() - Method in class org.springframework.integration.twitter.core.Tweet
 
getFromUserId() - Method in class org.springframework.integration.twitter.core.Tweet
 
getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.httpinvoker.config.HttpInvokerOutboundGatewayParser
Deprecated.  
getGatewayClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
 
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.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
 
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.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
 
getId() - Method in class org.springframework.integration.twitter.core.Tweet
 
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.config.xml.AbstractConsumerEndpointParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
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.jms.config.JmsOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
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.
getLanguageCode() - Method in class org.springframework.integration.twitter.core.Tweet
 
getLastRead() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
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.AbstractTcpConnection
 
getMappingKeyAttributeValue() - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
getMappingKeyAttributeValue() - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
getMappingKeyAttributeValue() - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
getMarked() - Method in interface org.springframework.integration.store.MessageGroup
 
getMarked() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getMarkedMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMarkedMessageCountForAllMessageGroups() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMarkedMessageCountForAllMessageGroups() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of marked messages in the store for all groups.
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
 
getMaxId() - Method in class org.springframework.integration.twitter.core.SearchResults
Returns the maximum Tweet ID in the search results
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
 
getMentions() - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getMentions(long) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getMentions() - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
getMentions(long) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
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() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
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
 
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.monitor.LifecycleMessageSourceMetrics
 
getMessageCount() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
 
getMessageCount() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
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 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
 
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
 
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
 
getMultiFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
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.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
 
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.config.FileWritingMessageHandlerFactoryBean
 
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.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.config.FileWritingMessageHandlerFactoryBean
 
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
 
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
 
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
 
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.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.store.MessageGroupStoreReaper
 
getPhase() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
getPhase() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
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
 
getProfileId() - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getProfileId() - Method in interface org.springframework.integration.twitter.core.TwitterOperations
Retrieves the user's Twitter screen name.
getProfileImageUrl() - Method in class org.springframework.integration.twitter.core.Tweet
 
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
 
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.ftp.config.FtpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getRemainingCapacity() - Method in class org.springframework.integration.monitor.QueueChannelMetrics
 
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".
getScriptAsString() - Method in class org.springframework.integration.groovy.config.RefreshableResourceScriptSource
 
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.
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
 
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.AbstractTcpConnection
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
getSerializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
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.ftp.config.FtpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getSinceId() - Method in class org.springframework.integration.twitter.core.SearchResults
Returns the Tweet ID after which all of the matching Tweets were created
getSize() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
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.tcp.connection.AbstractConnectionFactory
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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
 
getSource() - Method in class org.springframework.integration.twitter.core.Tweet
 
getSourceMessageCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
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
 
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
 
getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
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
 
getText() - Method in class org.springframework.integration.twitter.core.Tweet
 
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.AbstractTcpConnectionInterceptor
Returns the underlying connection (or next interceptor)
getTimeline() - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getTimeline(long) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getTimeline() - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
getTimeline(long) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
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.SimpleMessageGroup
 
getToUserId() - Method in class org.springframework.integration.twitter.core.Tweet
 
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
 
getTweets() - Method in class org.springframework.integration.twitter.core.SearchResults
Returns the list of matching Tweets
getTwitterStatusCode() - Method in exception org.springframework.integration.twitter.core.TwitterOperationException
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getUnderlyingTwitter() - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
getUnderlyingTwitter() - Method in interface org.springframework.integration.twitter.core.TwitterOperations
Temporary method.
getUnmarked() - Method in interface org.springframework.integration.store.MessageGroup
 
getUnmarked() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
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
 
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
 
group - Variable in class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
 

H

handleError(Throwable) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
handleMailMessagingException(MessagingException) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
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
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
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.handler.AbstractMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
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.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.
handleRequest(HttpServletRequest, HttpServletResponse) - Method in class org.springframework.integration.httpinvoker.HttpInvokerInboundGateway
Deprecated.  
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.filter.MessageFilter
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.gateway.AbstractRemotingOutboundGateway
Deprecated.  
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.jms.JmsOutboundGateway
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
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.
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
 
host - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
host - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
host - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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
 
HttpInvokerInboundGateway - Class in org.springframework.integration.httpinvoker
Deprecated. as of 2.0.x. We recommend using the REST-based HTTP adapters instead.
HttpInvokerInboundGateway() - Constructor for class org.springframework.integration.httpinvoker.HttpInvokerInboundGateway
Deprecated.  
HttpInvokerInboundGatewayParser - Class in org.springframework.integration.httpinvoker.config
Deprecated. as of 2.0.x. We recommend using the REST-based HTTP adapters instead.
HttpInvokerInboundGatewayParser() - Constructor for class org.springframework.integration.httpinvoker.config.HttpInvokerInboundGatewayParser
Deprecated.  
HttpInvokerNamespaceHandler - Class in org.springframework.integration.httpinvoker.config
Deprecated. as of 2.0.x. We recommend using the REST-based HTTP adapters instead.
HttpInvokerNamespaceHandler() - Constructor for class org.springframework.integration.httpinvoker.config.HttpInvokerNamespaceHandler
Deprecated.  
HttpInvokerOutboundGateway - Class in org.springframework.integration.httpinvoker
Deprecated. as of 2.0.x. We recommend using the REST-based HTTP adapters instead.
HttpInvokerOutboundGateway(String) - Constructor for class org.springframework.integration.httpinvoker.HttpInvokerOutboundGateway
Deprecated.  
HttpInvokerOutboundGatewayParser - Class in org.springframework.integration.httpinvoker.config
Deprecated. as of 2.0.x. We recommend using the REST-based HTTP adapters instead.
HttpInvokerOutboundGatewayParser() - Constructor for class org.springframework.integration.httpinvoker.config.HttpInvokerOutboundGatewayParser
Deprecated.  
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.
indexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
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.groovy.config.GroovyNamespaceHandler
 
init() - Method in class org.springframework.integration.http.config.HttpNamespaceHandler
 
init() - Method in class org.springframework.integration.httpinvoker.config.HttpInvokerNamespaceHandler
Deprecated.  
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.rmi.config.RmiNamespaceHandler
 
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.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
 
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
 
interceptorFactoryChain - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
interceptorFactoryChain - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.SimpleWebServiceInboundGateway
 
invokeInternal(Object) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
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.
IpAdapterParserUtils() - Constructor for class org.springframework.integration.ip.config.IpAdapterParserUtils
 
IpHeaders - Class in org.springframework.integration.ip
Headers for Messages mapped from IP datagram packets.
IpHeaders() - Constructor for class org.springframework.integration.ip.IpHeaders
 
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
 
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
 
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.store.MessageGroupStoreReaper
 
isAutoStartup() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
isAutoStartup() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
isComplete() - Method in interface org.springframework.integration.store.MessageGroup
 
isComplete() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
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
 
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.TcpOutboundGateway
 
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.groovy.config.RefreshableResourceScriptSource
 
isOpen() - Method in interface org.springframework.integration.file.remote.session.Session
 
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.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.TcpNetClientConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
isRunning() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
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.store.MessageGroupStoreReaper
 
isRunning() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
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.config.FileWritingMessageHandlerFactoryBean
 
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
 
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.store.AbstractMessageGroupStore
 
iterator() - Method in class org.springframework.integration.store.MessageGroupQueue
 
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
 
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
 
list(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
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
 
listener - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
listener - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
listener - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
listening - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
listening - Variable in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
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
 
LoadBalancingStrategy - Interface in org.springframework.integration.dispatcher
Strategy for determining the iteration order of a MessageHandler list.
localAddress - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
localAddress - Variable in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
localAddress - Variable in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
localAddress - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
locateComponentInHistory(MessageHistory, String, int) - Static method in class org.springframework.integration.test.util.TestUtils
 
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.handler.AbstractMessageHandler
 
logger - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
logger - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
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.ip.tcp.TcpSendingMessageHandler
 
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.monitor.DirectChannelMetrics
 
logger - Variable in class org.springframework.integration.store.AbstractMessageGroupStore
 
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
 

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.
mapper - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
mapper - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
mapper - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
mapper - Variable in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
mapper - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
MapToObjectTransformer - Class in org.springframework.integration.transformer
Will transform Map to an instance of Object.
MapToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformer(String) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
MapToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
mark(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
Mark the given message in this group.
markAll() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
marked - Variable in class org.springframework.integration.store.SimpleMessageGroup
 
markMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Persist a mark on a single message from the group.
markMessageFromGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist a mark on a single message from the group.
markMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
markMessageGroup(MessageGroup) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
markMessageGroup(MessageGroup) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist the mark on all the messages from the group.
markMessageGroup(MessageGroup) - Method in class org.springframework.integration.store.SimpleMessageStore
 
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
 
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
Handles forwarding all new Status that are 'replies' or 'mentions' to some other tweet.
MentionsReceivingMessageSource(TwitterOperations) - 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_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
 
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.
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
 
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
 
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
 
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
 
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 - Interface in org.springframework.integration.store
Strategy interface for storing and retrieving messages.
MessageTimeoutException - Exception in org.springframework.integration
Exception that indicates a timeout elapsed prior to successful message delivery.
MessageTimeoutException(String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTransformationException - Exception in org.springframework.integration.transformer
Base Exception type for Message transformation errors.
MessageTransformationException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(Message<?>, String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformingChannelInterceptor - Class in org.springframework.integration.transformer
A ChannelInterceptor which invokes a Transformer when either sending-to or receiving-from a channel.
MessageTransformingChannelInterceptor(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
MessageTransformingHandler - Class in org.springframework.integration.transformer
A reply-producing MessageHandler that delegates to a Transformer instance to modify the received Message and sends the result to its output channel.
MessageTransformingHandler(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingHandler
Create a MessageTransformingHandler instance that delegates to the provided Transformer.
messageWithHeaderEntries(Map<String, ?>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderEntry(String, Object) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderEntry(String, Matcher<T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithHeaderKey(String) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithPayload(Matcher<T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
messageWithPayload(T) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
MessagingAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
A BeanPostProcessor implementation that processes method-level messaging annotations such as @Transformer, @Splitter, @Router, and @Filter.
MessagingAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
MessagingEvent - Class in org.springframework.integration.event.core
A subclass of ApplicationEvent that wraps a Message.
MessagingEvent(Message<?>) - Constructor for class org.springframework.integration.event.core.MessagingEvent
 
MessagingException - Exception in org.springframework.integration
The base exception for any failures related to messaging.
MessagingException(Message<?>) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(String) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(String, Throwable) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(Message<?>, String) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingGatewaySupport - Class in org.springframework.integration.gateway
A convenient base class for connecting application code to MessageChannels for sending, receiving, or request-reply operations.
MessagingGatewaySupport() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
 
MessagingMethodInvokerHelper<T> - Class in org.springframework.integration.util
A helper class for processors that invoke a method on a target Object using a combination of message payload(s) and headers as arguments.
MessagingMethodInvokerHelper(Object, Method, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Method, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingOperations - Interface in org.springframework.integration.core
Specifies a basic set of messaging operations.
MessagingTemplate - Class in org.springframework.integration.core
This is the central class for invoking message exchange operations across MessageChannels.
MessagingTemplate() - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with no default channel.
MessagingTemplate(MessageChannel) - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with the given default channel.
METADATA_STORE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
MetadataStore - Interface in org.springframework.integration.store
Strategy interface for storing metadata from certain adapters to avoid duplicate delivery of messages, for example.
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
MethodAnnotationPostProcessor<T extends java.lang.annotation.Annotation> - Interface in org.springframework.integration.config.annotation
Strategy interface for post-processing annotated methods.
MethodAnnotationPublisherMetadataSource - Class in org.springframework.integration.aop
An PublisherMetadataSource implementation that retrieves the channel name and expression strings from an annotation.
MethodAnnotationPublisherMetadataSource() - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodAnnotationPublisherMetadataSource(Set<Class<? extends Annotation>>) - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodInvokingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that works as an adapter to another bean.
MethodInvokingCorrelationStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingCorrelationStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the <inbound-channel-adapter/> element.
MethodInvokingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.MethodInvokingInboundChannelAdapterParser
 
MethodInvokingMessageGroupProcessor - Class in org.springframework.integration.aggregator
MessageGroupProcessor that serves as an adapter for the invocation of a POJO method.
MethodInvokingMessageGroupProcessor(Object) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that invokes the specified method on the provided object.
MethodInvokingMessageHandler(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageHandler(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageListProcessor<T> - Class in org.springframework.integration.aggregator
A MessageListProcessor implementation that invokes a method on a target POJO.
MethodInvokingMessageListProcessor(Object, Method, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageProcessor<T> - Class in org.springframework.integration.handler
A MessageProcessor implementation that invokes a method on a target Object.
MethodInvokingMessageProcessor(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String, boolean) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageSource - Class in org.springframework.integration.endpoint
A MessageSource implementation that invokes a no-argument method so that its return value may be sent to a channel.
MethodInvokingMessageSource() - Constructor for class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
MethodInvokingOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the <outbound-channel-adapter/> element.
MethodInvokingOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.MethodInvokingOutboundChannelAdapterParser
 
MethodInvokingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that invokes a method on a plain old Java object.
MethodInvokingReleaseStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingReleaseStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingRouter - Class in org.springframework.integration.router
A Message Router that invokes the specified method on the given object.
MethodInvokingRouter(Object, Method) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object, String) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingSelector - Class in org.springframework.integration.filter
A method-invoking implementation of MessageSelector.
MethodInvokingSelector(Object, Method) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object, String) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that invokes the specified method on the given object.
MethodInvokingSplitter(Object, Method) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object, String) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that invokes the specified method on the given object.
MethodInvokingTransformer(Object, Method) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object, String) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodNameMappingPublisherMetadataSource - Class in org.springframework.integration.aop
 
MethodNameMappingPublisherMetadataSource(Map<String, String>) - Constructor for class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
mkdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
MockitoMessageMatchers - Class in org.springframework.integration.test.matcher
Mockito matcher factory for Message matcher creation.
MockitoMessageMatchers() - Constructor for class org.springframework.integration.test.matcher.MockitoMessageMatchers
 
MulticastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
Channel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.
MulticastReceivingChannelAdapter(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
MulticastReceivingChannelAdapter(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
MulticastSendingMessageHandler - Class in org.springframework.integration.ip.udp
A MessageHandler implementation that maps a Message into a UDP datagram packet and sends that to the specified multicast address (224.0.0.0 to 239.255.255.255) and port.
MulticastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port.
MulticastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the lengthCheck option (if set, a length is prepended to the packet and checked at the destination).
MulticastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
MulticastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
MULTIPART_MODE - Static variable in class org.springframework.integration.mail.MailHeaders
 
MultipartAwareFormHttpMessageConverter - Class in org.springframework.integration.http.converter
An HttpMessageConverter implementation that delegates to an instance of XmlAwareFormHttpMessageConverter while adding the capability to read multipart/form-data content in an HTTP request.
MultipartAwareFormHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
MultipartFileReader<T> - Interface in org.springframework.integration.http.multipart
Strategy for reading MultipartFile content.
MultipartHttpInputMessage - Class in org.springframework.integration.http.multipart
 
MultipartHttpInputMessage(MultipartHttpServletRequest) - Constructor for class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 

N

NAME_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
NamedComponent - Interface in org.springframework.integration.context
 
newChannels - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
NioFileLocker - Class in org.springframework.integration.file.locking
File locking strategy that uses java.nio.
NioFileLocker() - Constructor for class org.springframework.integration.file.locking.NioFileLocker
 
NoListenerException - Exception in org.springframework.integration.ip.tcp.connection
 
NoListenerException(String, Throwable) - Constructor for exception org.springframework.integration.ip.tcp.connection.NoListenerException
 
NoListenerException(String) - Constructor for exception org.springframework.integration.ip.tcp.connection.NoListenerException
 
NOTIFICATION_HANDBACK - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
NOTIFICATION_TYPE - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
NotificationListeningChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
NotificationListeningChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
NotificationListeningMessageProducer - Class in org.springframework.integration.jmx
A JMX NotificationListener implementation that will send Messages containing the JMX Notification instances as their payloads.
NotificationListeningMessageProducer() - Constructor for class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
NotificationPublishingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
NotificationPublishingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
NotificationPublishingMessageHandler - Class in org.springframework.integration.jmx
 
NotificationPublishingMessageHandler(ObjectName) - Constructor for class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
NotificationPublishingMessageHandler(String) - Constructor for class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
NULL_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
NullChannel - Class in org.springframework.integration.channel
A channel implementation that essentially behaves like "/dev/null".
NullChannel() - Constructor for class org.springframework.integration.channel.NullChannel
 

O

OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
ObjectToJsonTransformer - Class in org.springframework.integration.json
Transformer implementation that converts a payload instance into a JSON string representation.
ObjectToJsonTransformer(ObjectMapper) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
ObjectToMapTransformer - Class in org.springframework.integration.transformer
Will transform an object graph into a flat Map where keys are valid SpEL expressions and values are of java.lang.* type.
ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
 
ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
ObjectToStringTransformer - Class in org.springframework.integration.transformer
A simple transformer that creates an outbound payload by invoking the inbound payload Object's toString() method.
ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
 
ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'object-to-string-transformer' element.
ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
obtain(Object) - Method in class org.springframework.integration.util.DefaultLockRegistry
Obtains a lock by masking the lockKey's hashCode() with the mask and using the result as an index to the lock table.
obtain(Object) - Method in interface org.springframework.integration.util.LockRegistry
Obtains the lock associated with the parameter object.
obtainSecurityMetadataSource() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
 
ONE_MINUTE_SECONDS - Static variable in class org.springframework.integration.monitor.DirectChannelMetrics
 
ONE_SECOND_SECONDS - Static variable in class org.springframework.integration.monitor.DirectChannelMetrics
 
onFailure(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
Adds the failed message back to the 'toBeReceived' queue if there is room.
onInit() - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
 
onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Callback method for initialization.
onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this for initialization logic.
onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
onInit() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
onInit() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
onInit() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
onInit() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
onInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
onInit() - Method in class org.springframework.integration.filter.MessageFilter
 
onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.DelayHandler
 
onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
onInit() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
onInit() - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
onInit() - Method in class org.springframework.integration.httpinvoker.HttpInvokerInboundGateway
Deprecated.  
onInit() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
onInit() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
onInit() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
onInit() - Method in class org.springframework.integration.jms.JmsOutboundGateway
 
onInit() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
onInit() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
onInit() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
onInit() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
onInit() - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
onInit() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
onInit() - Method in class org.springframework.integration.router.RecipientListRouter
 
onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
onInit() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
onMessage(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpListener
Called by a TCPConnection when a new message arrives.
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
onMessage(Message, Session) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
onSend(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
The message is just logged.
openFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
OPERATION_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
OperationInvokingChannelAdapterParser - Class in org.springframework.integration.jmx.config
 
OperationInvokingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
OperationInvokingMessageHandler - Class in org.springframework.integration.jmx
A MessageHandler implementation for invoking JMX operations based on the Message sent to its AbstractMessageHandler.handleMessage(Message) method.
OperationInvokingMessageHandler() - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
OperationInvokingOutboundGatewayParser - Class in org.springframework.integration.jmx.config
 
OperationInvokingOutboundGatewayParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
Orderable - Interface in org.springframework.integration.context
Interface that extends Ordered while also exposing the Orderable.setOrder(int) as an interface-level so that it is avaiable on AOP proxies, etc.
org.springframework.integration - package org.springframework.integration
 
org.springframework.integration.aggregator - package org.springframework.integration.aggregator
 
org.springframework.integration.annotation - package org.springframework.integration.annotation
 
org.springframework.integration.aop - package org.springframework.integration.aop
 
org.springframework.integration.channel - package org.springframework.integration.channel
 
org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
 
org.springframework.integration.config - package org.springframework.integration.config
 
org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
 
org.springframework.integration.config.xml - package org.springframework.integration.config.xml
 
org.springframework.integration.context - package org.springframework.integration.context
 
org.springframework.integration.core - package org.springframework.integration.core
 
org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
 
org.springframework.integration.endpoint - package org.springframework.integration.endpoint
 
org.springframework.integration.event.config - package org.springframework.integration.event.config
 
org.springframework.integration.event.core - package org.springframework.integration.event.core
 
org.springframework.integration.event.inbound - package org.springframework.integration.event.inbound
 
org.springframework.integration.event.outbound - package org.springframework.integration.event.outbound
 
org.springframework.integration.expression - package org.springframework.integration.expression
 
org.springframework.integration.feed.config - package org.springframework.integration.feed.config
 
org.springframework.integration.feed.inbound - package org.springframework.integration.feed.inbound
 
org.springframework.integration.file - package org.springframework.integration.file
 
org.springframework.integration.file.config - package org.springframework.integration.file.config
 
org.springframework.integration.file.filters - package org.springframework.integration.file.filters
 
org.springframework.integration.file.locking - package org.springframework.integration.file.locking
 
org.springframework.integration.file.remote.handler - package org.springframework.integration.file.remote.handler
 
org.springframework.integration.file.remote.session - package org.springframework.integration.file.remote.session
 
org.springframework.integration.file.remote.synchronizer - package org.springframework.integration.file.remote.synchronizer
 
org.springframework.integration.file.transformer - package org.springframework.integration.file.transformer
 
org.springframework.integration.filter - package org.springframework.integration.filter
 
org.springframework.integration.ftp.config - package org.springframework.integration.ftp.config
 
org.springframework.integration.ftp.filters - package org.springframework.integration.ftp.filters
 
org.springframework.integration.ftp.inbound - package org.springframework.integration.ftp.inbound
 
org.springframework.integration.ftp.session - package org.springframework.integration.ftp.session
 
org.springframework.integration.gateway - package org.springframework.integration.gateway
 
org.springframework.integration.groovy - package org.springframework.integration.groovy
 
org.springframework.integration.groovy.config - package org.springframework.integration.groovy.config
 
org.springframework.integration.handler - package org.springframework.integration.handler
 
org.springframework.integration.history - package org.springframework.integration.history
 
org.springframework.integration.http - package org.springframework.integration.http
 
org.springframework.integration.http.config - package org.springframework.integration.http.config
 
org.springframework.integration.http.converter - package org.springframework.integration.http.converter
 
org.springframework.integration.http.inbound - package org.springframework.integration.http.inbound
 
org.springframework.integration.http.multipart - package org.springframework.integration.http.multipart
 
org.springframework.integration.http.outbound - package org.springframework.integration.http.outbound
 
org.springframework.integration.http.support - package org.springframework.integration.http.support
 
org.springframework.integration.httpinvoker - package org.springframework.integration.httpinvoker
 
org.springframework.integration.httpinvoker.config - package org.springframework.integration.httpinvoker.config
 
org.springframework.integration.ip - package org.springframework.integration.ip
 
org.springframework.integration.ip.config - package org.springframework.integration.ip.config
 
org.springframework.integration.ip.tcp - package org.springframework.integration.ip.tcp
 
org.springframework.integration.ip.tcp.connection - package org.springframework.integration.ip.tcp.connection
All things related to tcp connections - client and server factories; listener and sender interfaces.
org.springframework.integration.ip.tcp.serializer - package org.springframework.integration.ip.tcp.serializer
Byte array (de)serializers for putting some protocol on the wire so that incoming messages can be constructed from stream data.
org.springframework.integration.ip.udp - package org.springframework.integration.ip.udp
 
org.springframework.integration.ip.util - package org.springframework.integration.ip.util
 
org.springframework.integration.jdbc - package org.springframework.integration.jdbc
 
org.springframework.integration.jdbc.config - package org.springframework.integration.jdbc.config
 
org.springframework.integration.jms - package org.springframework.integration.jms
 
org.springframework.integration.jms.config - package org.springframework.integration.jms.config
 
org.springframework.integration.jmx - package org.springframework.integration.jmx
 
org.springframework.integration.jmx.config - package org.springframework.integration.jmx.config
 
org.springframework.integration.json - package org.springframework.integration.json
 
org.springframework.integration.mail - package org.springframework.integration.mail
 
org.springframework.integration.mail.config - package org.springframework.integration.mail.config
 
org.springframework.integration.mail.transformer - package org.springframework.integration.mail.transformer
 
org.springframework.integration.mapping - package org.springframework.integration.mapping
 
org.springframework.integration.message - package org.springframework.integration.message
 
org.springframework.integration.monitor - package org.springframework.integration.monitor
 
org.springframework.integration.rmi - package org.springframework.integration.rmi
 
org.springframework.integration.rmi.config - package org.springframework.integration.rmi.config
 
org.springframework.integration.router - package org.springframework.integration.router
 
org.springframework.integration.scheduling - package org.springframework.integration.scheduling
 
org.springframework.integration.scripting - package org.springframework.integration.scripting
 
org.springframework.integration.security.channel - package org.springframework.integration.security.channel
 
org.springframework.integration.security.config - package org.springframework.integration.security.config
 
org.springframework.integration.selector - package org.springframework.integration.selector
 
org.springframework.integration.sftp.config - package org.springframework.integration.sftp.config
 
org.springframework.integration.sftp.filters - package org.springframework.integration.sftp.filters
 
org.springframework.integration.sftp.inbound - package org.springframework.integration.sftp.inbound
 
org.springframework.integration.sftp.session - package org.springframework.integration.sftp.session
 
org.springframework.integration.splitter - package org.springframework.integration.splitter
 
org.springframework.integration.store - package org.springframework.integration.store
 
org.springframework.integration.stream - package org.springframework.integration.stream
 
org.springframework.integration.stream.config - package org.springframework.integration.stream.config
 
org.springframework.integration.support - package org.springframework.integration.support
 
org.springframework.integration.support.channel - package org.springframework.integration.support.channel
 
org.springframework.integration.support.converter - package org.springframework.integration.support.converter
 
org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
 
org.springframework.integration.test.util - package org.springframework.integration.test.util
 
org.springframework.integration.transformer - package org.springframework.integration.transformer
 
org.springframework.integration.twitter.config - package org.springframework.integration.twitter.config
 
org.springframework.integration.twitter.core - package org.springframework.integration.twitter.core
 
org.springframework.integration.twitter.inbound - package org.springframework.integration.twitter.inbound
 
org.springframework.integration.twitter.outbound - package org.springframework.integration.twitter.outbound
 
org.springframework.integration.util - package org.springframework.integration.util
 
org.springframework.integration.ws - package org.springframework.integration.ws
 
org.springframework.integration.ws.config - package org.springframework.integration.ws.config
 
org.springframework.integration.xml - package org.springframework.integration.xml
 
org.springframework.integration.xml.config - package org.springframework.integration.xml.config
 
org.springframework.integration.xml.result - package org.springframework.integration.xml.result
 
org.springframework.integration.xml.router - package org.springframework.integration.xml.router
 
org.springframework.integration.xml.selector - package org.springframework.integration.xml.selector
 
org.springframework.integration.xml.source - package org.springframework.integration.xml.source
 
org.springframework.integration.xml.splitter - package org.springframework.integration.xml.splitter
 
org.springframework.integration.xml.transformer - package org.springframework.integration.xml.transformer
 
org.springframework.integration.xml.xpath - package org.springframework.integration.xml.xpath
 
org.springframework.integration.xmpp - package org.springframework.integration.xmpp
 
org.springframework.integration.xmpp.config - package org.springframework.integration.xmpp.config
 
org.springframework.integration.xmpp.core - package org.springframework.integration.xmpp.core
 
org.springframework.integration.xmpp.inbound - package org.springframework.integration.xmpp.inbound
 
org.springframework.integration.xmpp.outbound - package org.springframework.integration.xmpp.outbound
 
ORIGINAL_FILE - Static variable in class org.springframework.integration.file.FileHeaders
 
outboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Factory method for creating a basic outbound mapper instance.
OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
Strategy interface for mapping from a Message to an Object.

P

parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AnnotationConfigParser
 
parse(Element, ParserContext) - Method in interface org.springframework.integration.config.xml.BeanDefinitionRegisteringParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.WireTapParser
 
parseAndRegisterConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this method to control the registration process and return the bean name.
parseAndRegisterConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.MethodInvokingOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this method to return the BeanDefinition for the MessageConsumer.
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.LoggingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.MethodInvokingOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.mail.config.MailOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.stream.config.ConsoleOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.twitter.config.TwitterOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
Parse the MessageHandler.
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AggregatorParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.BridgeParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ControlBusParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DelayerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RecipientListRouterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ResequencerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.groovy.config.GroovyControlBusParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
parseInnerHandlerDefinition(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
parseInterceptors(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ConverterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishingInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.ip.config.TcpConnectionParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcMessageStoreParser
 
parseNamespaceMapElement(Element, ParserContext, BeanDefinition) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
parseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
Subclasses must implement this method to parse the PollableSource instance which the created Channel Adapter will poll.
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.MethodInvokingInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.feed.config.FeedInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.file.config.FileInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.mail.config.MailInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.stream.config.ConsoleInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.twitter.config.TwitterInboundChannelAdapterParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.mail.config.MailToStringTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.MarshallingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.UnmarshallingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XsltPayloadTransformerParser
 
parseUrl(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseUrl(Element, ParserContext) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
 
PassThroughMessageGroupProcessor - Class in org.springframework.integration.aggregator
This implementation of MessageGroupProcessor will return all unmarked messages inside the group.
PassThroughMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
 
password - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
Payload - Annotation Type in org.springframework.integration.annotation
This annotation allows you to specify a SpEL expression indicating that a method parameter's value should be mapped from the payload of a Message.
PayloadAndHeaderMatcher - Class in org.springframework.integration.test.matcher
Matcher to make assertions about message equality easier.
PayloadDeserializingTransformer - Class in org.springframework.integration.transformer
Transformer that deserializes the inbound byte array payload to an object by delegating to a Converter<byte[], Object>.
PayloadDeserializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
PayloadDeserializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-deserializing-transformer' element.
PayloadDeserializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
PayloadMatcher - Class in org.springframework.integration.test.matcher
Is the payload of a Message equal to a given value or is matching a given matcher?
Payloads - Annotation Type in org.springframework.integration.annotation
This annotation marks a method parameter as being a list of message payloads, for POJO handlers that deal with lists of messages (e.g.
PayloadSerializingTransformer - Class in org.springframework.integration.transformer
Transformer that serializes the inbound payload into a byte array by delegating to a Converter<Object, byte[]>.
PayloadSerializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadSerializingTransformer
 
PayloadSerializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-serializing-transformer' element.
PayloadSerializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
PayloadTypeConvertingTransformer<T,U> - Class in org.springframework.integration.transformer
Transformer that converts the inbound payload to an object by delegating to a Converter<Object, Object>.
PayloadTypeConvertingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
PayloadTypeRouter - Class in org.springframework.integration.router
A Message Router that resolves the MessageChannel based on the Message's payload type.
PayloadTypeRouter() - Constructor for class org.springframework.integration.router.PayloadTypeRouter
 
PayloadTypeRouterParser - Class in org.springframework.integration.config.xml
Parser for the <payload-type-router/> element.
PayloadTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
PayloadTypeSelector - Class in org.springframework.integration.selector
A MessageSelector implementation that checks the type of the Message payload.
PayloadTypeSelector(Class<?>...) - Constructor for class org.springframework.integration.selector.PayloadTypeSelector
Create a selector for the provided types.
peek() - Method in class org.springframework.integration.store.MessageGroupQueue
 
PointToPointChannelParser - Class in org.springframework.integration.config.xml
Parser for the <channel> element.
PointToPointChannelParser() - Constructor for class org.springframework.integration.config.xml.PointToPointChannelParser
 
poll() - Method in class org.springframework.integration.store.MessageGroupQueue
 
poll(long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
PollableChannel - Interface in org.springframework.integration.core
Interface for Message Channels from which Messages may be actively received through polling.
PollableChannelMetrics - Class in org.springframework.integration.monitor
 
PollableChannelMetrics(MessageChannel, String) - Constructor for class org.springframework.integration.monitor.PollableChannelMetrics
 
PollableJmsChannel - Class in org.springframework.integration.jms
 
PollableJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.PollableJmsChannel
 
PollerMetadata - Class in org.springframework.integration.scheduling
 
PollerMetadata() - Constructor for class org.springframework.integration.scheduling.PollerMetadata
 
PollerParser - Class in org.springframework.integration.config.xml
Parser for the <poller> element.
PollerParser() - Constructor for class org.springframework.integration.config.xml.PollerParser
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.DirectMessageReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
pollForTweets(long) - Method in class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
 
PollingConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a PollableChannel.
PollingConsumer(PollableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.PollingConsumer
 
poolSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
poolSize - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
poolSize - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
Pop3MailReceiver - Class in org.springframework.integration.mail
A MailReceiver implementation that polls a mail server using the POP3 protocol.
Pop3MailReceiver() - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String, String, String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
Pop3MailReceiver(String, int, String, String) - Constructor for class org.springframework.integration.mail.Pop3MailReceiver
 
popSequenceDetails() - Method in class org.springframework.integration.support.MessageBuilder
 
port - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
port - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
port - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
port - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
port - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
postProcess(Object, String, Method, T) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
postProcess(Object, String, Method, T) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultRouterParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.GatewayParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
postProcess(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
postProcess(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
 
postProcessClientAfterConnect(T) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Will handle additional initialization after client.connect() method was invoked, but before any action on the client has been taken
postProcessClientAfterConnect(FTPSClient) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
postProcessClientBeforeConnect(T) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
Will handle additional initialization before client.connect() method was invoked.
postProcessClientBeforeConnect(FTPSClient) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
Subclasses may override this method for additional configuration.
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
Subclasses may override this method to provide any additional processing.
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
postProcessMessage(Message<?>) - Method in interface org.springframework.integration.core.MessagePostProcessor
Apply a MessagePostProcessor to the message.
postProcessMessage(Message<?>) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
postProcessTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
Subclasses may override this method to provide additional configuration.
postProcessTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.file.config.FileToStringTransformerParser
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
postReceive(Message<?>, MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
Invoked immediately after a Message has been retrieved but before it is returned to the caller.
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
postSend(Message<?>, MessageChannel, boolean) - Method in interface org.springframework.integration.channel.ChannelInterceptor
Invoked immediately after the send invocation.
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
PREFIX - Static variable in class org.springframework.integration.jms.JmsHeaders
Prefix used for JMS API related headers in order to distinguish from user-defined headers and other internal headers (e.g.
PREFIX - Static variable in class org.springframework.integration.jmx.JmxHeaders
 
PREFIX - Static variable in class org.springframework.integration.mail.MailHeaders
 
PREFIX - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
preReceive(MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preReceive(MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
Invoked as soon as receive is called and before a Message is actually retrieved.
preReceive(MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
PresenceInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:presence-inbound-channel-adapter' element.
PresenceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.PresenceInboundChannelAdapterParser
 
PresenceListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
An inbound endpoint that is able to login and then emit Messages when a particular Presence event occurs within the logged-in user's Roster.
PresenceListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
PresenceListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
 
PresenceOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
Parser for 'xmpp:presence-outbound-channel-adapter' element
PresenceOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.PresenceOutboundChannelAdapterParser
 
PresenceSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
MessageHandler that publishes updated Presence values for a given XMPP connection.
PresenceSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
PresenceSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preSend(Message<?>, MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
Invoked before the Message is actually sent to the channel.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.WireTap
Intercept the Message and, if accepted by the MessageSelector, send it to the secondary target.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
PRIORITY - Static variable in class org.springframework.integration.MessageHeaders
 
PriorityChannel - Class in org.springframework.integration.channel
A message channel that prioritizes messages based on a Comparator.
PriorityChannel(int, Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(int) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
PriorityChannel() - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
process(Collection<? extends Message<?>>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Processes the Message by evaluating the expression with that Message as the root object.
process(Collection<? extends Message<?>>) - Method in interface org.springframework.integration.aggregator.MessageListProcessor
 
process(Collection<? extends Message<?>>, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
process(Message<?>) - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
process(Collection<Message<?>>, Map<String, ?>) - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
processHeaders(Element, ManagedMap<String, Object>, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
processHeaders(Element, ManagedMap<String, Object>, ParserContext) - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
Evaluates the Message payload expression as a command.
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Processes the Message by evaluating the expression with that Message as the root object.
processMessage(Message<?>) - Method in interface org.springframework.integration.handler.MessageProcessor
Process the Message and return a value (or null).
processMessage(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Executes the script and returns the result.
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in interface org.springframework.integration.aggregator.MessageGroupProcessor
Process the given MessageGroup.
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
processNioSelections(int, Selector, ServerSocketChannel, Map<SocketChannel, TcpNioConnection>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Times out any expired connections then, if selectionCount > 0, processes the selected keys.
PropertiesPersistingMetadataStore - Class in org.springframework.integration.store
Properties file-based implementation of MetadataStore.
PropertiesPersistingMetadataStore() - Constructor for class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
Publisher - Annotation Type in org.springframework.integration.annotation
Annotation to indicate that a method, or all public methods if applied at class-level, should publish Messages.
PublisherAnnotationAdvisor - Class in org.springframework.integration.aop
An advisor that will apply the MessagePublishingInterceptor to any methods containing the provided annotations.
PublisherAnnotationAdvisor(Class<? extends Annotation>...) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationAdvisor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationBeanPostProcessor - Class in org.springframework.integration.aop
Post-processes beans that contain the method-level @Publisher annotation.
PublisherAnnotationBeanPostProcessor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
PublishingInterceptorParser - Class in org.springframework.integration.config.xml
Parser for the <publishing-interceptor> element.
PublishingInterceptorParser() - Constructor for class org.springframework.integration.config.xml.PublishingInterceptorParser
 
PublishSubscribeChannel - Class in org.springframework.integration.channel
A channel that sends Messages to each of its subscribers.
PublishSubscribeChannel(Executor) - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will use an Executor to invoke the handlers.
PublishSubscribeChannel() - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will invoke the handlers in the message sender's thread.
PublishSubscribeChannelParser - Class in org.springframework.integration.config.xml
Parser for the <publish-subscribe-channel> element.
PublishSubscribeChannelParser() - Constructor for class org.springframework.integration.config.xml.PublishSubscribeChannelParser
 
purge() - Method in class org.springframework.integration.channel.ChannelPurger
 
purge(MessageSelector) - Method in class org.springframework.integration.channel.QueueChannel
Remove any Messages that are not accepted by the provided selector.
pushSequenceDetails(Object, int, int) - Method in class org.springframework.integration.support.MessageBuilder
 
put(String, Object) - Method in class org.springframework.integration.MessageHeaders
Since MessageHeaders are immutable the call to this method will result in UnsupportedOperationException
put(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
put(String, String) - Method in interface org.springframework.integration.store.MetadataStore
Writes a key value pair to this MetadataStore.
put(String, String) - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
put(String, String) - Method in class org.springframework.integration.store.SimpleMetadataStore
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.springframework.integration.MessageHeaders
Since MessageHeaders are immutable the call to this method will result in UnsupportedOperationException

Q

QueueChannel - Class in org.springframework.integration.channel
Simple implementation of a message channel.
QueueChannel(BlockingQueue<Message<?>>) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue.
QueueChannel(int) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue capacity.
QueueChannel() - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with "unbounded" queue capacity.
QueueChannelMetrics - Class in org.springframework.integration.monitor
 
QueueChannelMetrics(QueueChannel, String) - Constructor for class org.springframework.integration.monitor.QueueChannelMetrics
 

R

read(String, OutputStream) - Method in interface org.springframework.integration.file.remote.session.Session
 
read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
 
read(Class<? extends MultiValueMap<String, ?>>, HttpInputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
read(InputStream, byte[], boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Reads data from the socket and puts the data in buffer.
readHeader(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Reads the header and returns the length of the data part.
readHeaders(JsonParser, String) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
readInternal(Class, HttpInputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.DefaultMultipartFileReader
 
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
 
readMultipartFile(MultipartFile) - Method in interface org.springframework.integration.http.multipart.MultipartFileReader
Reads MultipartFile content.
readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
 
readPacket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Invoked by the factory when there is data to be read.
readPayload(JsonParser, String) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive() - Method in class org.springframework.integration.channel.NullChannel
 
receive(long) - Method in class org.springframework.integration.channel.NullChannel
 
receive() - Method in interface org.springframework.integration.core.MessageSource
Retrieve the next available message from this source.
receive() - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the default channel, but only wait up to a specified time for delivery.
receive(PollableChannel) - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the specified channel, but only wait up to a specified time for delivery.
receive(String) - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the specified channel, but only wait up to a specified time for delivery.
receive() - Method in class org.springframework.integration.core.MessagingTemplate
 
receive(PollableChannel) - Method in class org.springframework.integration.core.MessagingTemplate
 
receive(String) - Method in class org.springframework.integration.core.MessagingTemplate
 
receive() - Method in interface org.springframework.integration.core.PollableChannel
Receive a message from this channel, blocking indefinitely if necessary.
receive(long) - Method in interface org.springframework.integration.core.PollableChannel
Receive a message from this channel, blocking until either a message is available or the specified timeout period elapses.
receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
receive() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
receive() - Method in class org.springframework.integration.file.FileReadingMessageSource
 
receive() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Polls from the file source.
receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
receive() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
Executes the query.
receive() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Will receive a JMS Message converting and returning it as a Spring Integration Message.
receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
 
receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
receive() - Method in interface org.springframework.integration.mail.MailReceiver
 
receive() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
receive() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
receive() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
receiveAndConvert() - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the default channel, but only wait up to a specified time for delivery.
receiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the specified channel, but only wait up to a specified time for delivery.
receiveAndConvert(String) - Method in interface org.springframework.integration.core.MessagingOperations
Receive a message synchronously from the specified channel, but only wait up to a specified time for delivery.
receiveAndConvert() - Method in class org.springframework.integration.core.MessagingTemplate
 
receiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.MessagingTemplate
 
receiveAndConvert(String) - Method in class org.springframework.integration.core.MessagingTemplate
 
receiveBufferSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
RecipientListRouter - Class in org.springframework.integration.router
<recipient-list-router id="simpleRouter" input-channel="routingChannelA"> <recipient channel="channel1"/> <recipient channel="channel2"/> </recipient-list-router>
RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
 
RecipientListRouter.Recipient - Class in org.springframework.integration.router
 
RecipientListRouter.Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
RecipientListRouter.Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
RecipientListRouterParser - Class in org.springframework.integration.config.xml
Parser for the <recipient-list-router/> element.
RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
 
RecursiveLeafOnlyDirectoryScanner - Class in org.springframework.integration.file
DirectoryScanner that lists all files inside a directory and subdirectories, without limit.
RecursiveLeafOnlyDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveLeafOnlyDirectoryScanner
 
REDELIVERED - Static variable in class org.springframework.integration.jms.JmsHeaders
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
RefreshableResourceScriptSource - Class in org.springframework.integration.groovy.config
 
RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.groovy.config.RefreshableResourceScriptSource
 
RegexPatternFileListFilter - Class in org.springframework.integration.file.filters
Implementation of AbstractRegexPatternMatchingFileListFilter for java.io.File instances.
RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
RegexUtils - Class in org.springframework.integration.ip.util
Regular Expression Utilities.
RegexUtils() - Constructor for class org.springframework.integration.ip.util.RegexUtils
 
registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
registerBeanDefinitionDecorator(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionDecoratorForAttribute(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionParser(String, BeanDefinitionParser) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeans() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
registerChannel(String, MessageChannel) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
 
registerEndpoint(String, AbstractEndpoint) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
 
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Registers a TcpListener to receive messages after the payload has been converted from the input data.
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
registerListener(TcpListener) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Sets the listener that will receive incoming Messages.
registerMessageGroupExpiryCallback(MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
registerMessageGroupExpiryCallback(MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
Register a callback for when a message group is expired through MessageGroupStore.expireMessageGroups(long).
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Registers a TcpSender; for server sockets, used to provide connection information so a sender can be used to reply to incoming messages.
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
registerSender(TcpSender) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Registers a sender.
release() - Method in class org.springframework.integration.util.UpperBound
Releases one lock on the underlying semaphore.
release(int) - Method in class org.springframework.integration.util.UpperBound
Releases several locks on the underlying semaphore.
ReleaseStrategy - Interface in org.springframework.integration.aggregator
Strategy for determining when a group of messages reaches a state of completion (i.e.
ReleaseStrategy - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of asserting if a list of messages or payload objects is complete.
ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a ReleaseStrategy.
ReleaseStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Create a factory and set up the delegate which clients of the factory will see as its product.
ReleaseStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Create a factory and set up the delegate which clients of the factory will see as its product.
ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
ExpressionSource implementation that accesses resource bundles using specified basenames.
ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
 
REMOTE_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
 
RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
 
RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
RemotingInboundGatewaySupport - Class in org.springframework.integration.gateway
Deprecated. as of 2.0. Will be removed in 2.1.
RemotingInboundGatewaySupport() - Constructor for class org.springframework.integration.gateway.RemotingInboundGatewaySupport
Deprecated.  
remove(String) - Method in interface org.springframework.integration.file.remote.session.Session
 
remove(int) - Method in class org.springframework.integration.history.MessageHistory
 
remove(Object) - Method in class org.springframework.integration.history.MessageHistory
 
remove(Object) - Method in class org.springframework.integration.MessageHeaders
Since MessageHeaders are immutable the call to this method will result in UnsupportedOperationException
remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
Removes channel mapping for a give channel identifier
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
removeDeadConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
When we are using sockets owned by a TcpListener, this method is called each time a connection is closed.
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Remove the handler from the internal handler Set.
removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
removeHeader(String) - Method in class org.springframework.integration.support.MessageBuilder
Remove the value for the given header name.
removeHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
Removes all headers provided via array of 'headerPatterns'.
removeMessage(UUID) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
Remove the Message with the given id from the MessageStore, if present, and return it.
removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
removeMessageFromGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist a deletion on a single message from the group.
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
removeMessageGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Remove the message group with this id.
removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
rename(String, String) - Method in interface org.springframework.integration.file.remote.session.Session
 
RendezvousChannel - Class in org.springframework.integration.channel
A zero-capacity version of QueueChannel that delegates to a SynchronousQueue internally.
RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
 
REPLY_CHANNEL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REPLY_CHANNEL - Static variable in class org.springframework.integration.MessageHeaders
 
REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REPLY_TO - Static variable in class org.springframework.integration.jms.JmsHeaders
 
REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
 
REQUEST_METHOD - Static variable in class org.springframework.integration.http.HttpHeaders
 
REQUEST_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
 
REQUEST_URL - Static variable in class org.springframework.integration.http.HttpHeaders
 
RequestReplyExchanger - Interface in org.springframework.integration.gateway
Interface for a request/reply Message exchange.
ResequencerParser - Class in org.springframework.integration.config.xml
Parser for the <resequencer> element.
ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
 
ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
This class implements all the strategy interfaces needed for a default resequencer.
ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
reset() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
reset() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
reset() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
 
reset() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
 
reset() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
 
reset() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
 
reset() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
resolveChannelName(String) - Method in class org.springframework.integration.core.MessagingTemplate
Resolve the given channel name into a MessageChannel, via this template's ChannelResolver if available.
resolveChannelName(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
resolveChannelName(String) - Method in interface org.springframework.integration.support.channel.ChannelResolver
Return the MessageChannel for the given name.
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
restartAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
If exposed as an MBean, can be used to restart the ack thread if a fatal (bind) error occurred, without bouncing the JVM.
ResultFactory - Interface in org.springframework.integration.xml.result
Factory to create a Result possibly taking into account the provided message payload instance.
ResultToDocumentTransformer - Class in org.springframework.integration.xml.transformer
Creates a Document from a Result payload.
ResultToDocumentTransformer(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
ResultToDocumentTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
ResultToStringTransformer - Class in org.springframework.integration.xml.transformer
Converts the passed Result to an instance of String.
ResultToStringTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
ResultTransformer - Interface in org.springframework.integration.xml.transformer
 
retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
RmiInboundGateway - Class in org.springframework.integration.rmi
An inbound Messaging Gateway for RMI-based remoting.
RmiInboundGateway() - Constructor for class org.springframework.integration.rmi.RmiInboundGateway
 
RmiInboundGatewayParser - Class in org.springframework.integration.rmi.config
Parser for the <inbound-gateway/> element of the 'rmi' namespace.
RmiInboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
RmiNamespaceHandler - Class in org.springframework.integration.rmi.config
Namespace handler for Spring Integration's rmi namespace.
RmiNamespaceHandler() - Constructor for class org.springframework.integration.rmi.config.RmiNamespaceHandler
 
RmiOutboundGateway - Class in org.springframework.integration.rmi
An outbound Messaging Gateway for RMI-based remoting.
RmiOutboundGateway(String) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
 
RmiOutboundGatewayParser - Class in org.springframework.integration.rmi.config
Parser for the <outbound-gateway/> element of the 'rmi' namespace.
RmiOutboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
 
RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
Round-robin implementation of LoadBalancingStrategy.
RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
 
Router - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of resolving to a channel or channel name based on a message, message header(s), or both.
RouterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Router.
RouterAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
 
RouterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Router.
RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
 
run() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
If there is no listener, and this connection is not for single use, this method exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
If no listener registers, exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
If there is no listener, and this connection is not for single use, this method exits.
run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
If no listener registers, exits.
run() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
run() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Process acknowledgments, if requested.
run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Expire all message groups older than the timeout provided.

S

sameExceptIgnorableHeaders(Message<?>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
SAVED_KEY - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
SCHEMA_RELAX_NG - Static variable in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
Constant that defines a RELAX NG Schema.
SCHEMA_W3C_XML - Static variable in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
Constant that defines a W3C XML Schema.
ScriptVariableGenerator - Interface in org.springframework.integration.scripting
 
search(String) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
search(String, long) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
search(String) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
Searches Twitter, returning the first page of Tweets
search(String, long) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
Searches Twitter, returning a specific page out of the complete set of results.
searchForNewMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Subclasses must implement this method to return new mail messages.
searchForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
Retrieves new messages from this receiver's folder.
searchForNewMessages() - Method in class org.springframework.integration.mail.Pop3MailReceiver
 
SearchReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
 
SearchReceivingMessageSource(TwitterOperations) - Constructor for class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
SearchResults - Class in org.springframework.integration.twitter.core
Represents the results of a Twitter search, including matching Tweets and any metadata associated with that search.
SearchResults(List<Tweet>, long, long) - Constructor for class org.springframework.integration.twitter.core.SearchResults
 
SecuredChannelsParser - Class in org.springframework.integration.security.config
Creates a ChannelSecurityInterceptor to control send and receive access, and creates a bean post-processor to apply the interceptor to MessageChannels whose names match the specified patterns.
SecuredChannelsParser() - Constructor for class org.springframework.integration.security.config.SecuredChannelsParser
 
SelectorChainParser - Class in org.springframework.integration.config.xml
Parser for the <selector-chain/> element.
SelectorChainParser() - Constructor for class org.springframework.integration.config.xml.SelectorChainParser
 
SelectorParser - Class in org.springframework.integration.config.xml
Parser for a top-level <selector/> element.
SelectorParser() - Constructor for class org.springframework.integration.config.xml.SelectorParser
 
semaphore - Variable in class org.springframework.integration.util.UpperBound
 
send(Message<?>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the default channel.
send(MessageChannel, Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the specified channel.
send(String, Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the specified channel.
send(Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
 
send(MessageChannel, Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
 
send(String, Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
 
send(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
send(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Converts and sends the message.
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
send(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
send(Message<?>) - Method in interface org.springframework.integration.MessageChannel
Send a Message to this channel.
send(Message<?>, long) - Method in interface org.springframework.integration.MessageChannel
Send a message, blocking until either the message is accepted or the specified timeout period elapses.
sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
sendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the default channel and receive a reply.
sendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the specified channel and receive a reply.
sendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
Send a message to the specified channel and receive a reply.
sendAndReceive(Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
 
sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
 
sendAndReceive(String, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
 
sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendDirectMessage(String, String) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
sendDirectMessage(int, String) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
sendDirectMessage(String, String) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
sendDirectMessage(int, String) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
 
sender - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
sender - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
sender - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
SEQUENCE_DETAILS - Static variable in class org.springframework.integration.MessageHeaders
 
SEQUENCE_NUMBER - Static variable in class org.springframework.integration.MessageHeaders
 
SEQUENCE_SIZE - Static variable in class org.springframework.integration.MessageHeaders
 
SequenceNumberComparator - Class in org.springframework.integration.aggregator
 
SequenceNumberComparator() - Constructor for class org.springframework.integration.aggregator.SequenceNumberComparator
 
SequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
An implementation of ReleaseStrategy that simply compares the current size of the message list to the expected 'sequenceSize'.
SequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
SequenceSizeReleaseStrategy(boolean) - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
Writes the byte[] to the stream and appends \r\n.
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Writes the byte[] to the output stream, preceded by a 4 byte length in network byte order (big endian).
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
 
serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
Writes the byte[] to the stream, prefixed by an ASCII STX character and terminated with an ASCII ETX character.
serializer - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
serializer - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
serializer - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
SerializingHttpMessageConverter - Class in org.springframework.integration.http.converter
An HttpMessageConverter implementation for Serializable instances.
SerializingHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.SerializingHttpMessageConverter
Creates a new instance of the SerializingHttpMessageConverter.
server - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
serverChannel - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
serverConnectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
serverConnectionFactory - Variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
serverSocket - Variable in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
serverSocket - Variable in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
SERVICE_NAME_PREFIX - Static variable in class org.springframework.integration.rmi.RmiInboundGateway
 
ServiceActivatingHandler - Class in org.springframework.integration.handler
 
ServiceActivatingHandler(Object) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, Method) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, String) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(MessageProcessor<T>) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of handling a message or message payload.
ServiceActivatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @ServiceActivator.
ServiceActivatorAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
ServiceActivatorFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating ServiceActivatingHandler instances.
ServiceActivatorFactoryBean() - Constructor for class org.springframework.integration.config.ServiceActivatorFactoryBean
 
ServiceActivatorParser - Class in org.springframework.integration.config.xml
Parser for the <service-activator> element.
ServiceActivatorParser() - Constructor for class org.springframework.integration.config.xml.ServiceActivatorParser
 
Session - Interface in org.springframework.integration.file.remote.session
Common abstraction for a Session with a remote File system.
SessionFactory - Interface in org.springframework.integration.file.remote.session
Factory for acquiring Session instances.
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
 
setAcceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setAckAddress(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Optional method allowing you to set additional flags.
setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.ImapMailReceiver
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setAlwaysUseResultFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Specify whether to always use result factory even for directly supported payload types
setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
If true always delegate to the SourceFactory.
setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Specify whether to always use source factory even for directly supported payload types.
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
 
setApplySequence(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether to apply the sequence number and size headers to the messages prior to invoking the subscribed handlers.
setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether to apply sequence numbers to the messages prior to sending to the handlers.
setApplySequence(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether to apply the sequence number and size headers to the messages prior to sending to the recipient channels.
setApplySequence(boolean) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Set the applySequence flag to the specified value.
setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the name of the attribute to be retrieved.
setAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setAuthValue(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify whether to create the source directory automatically if it does not yet exist upon initialization.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to create the destination directory automatically if it does not yet exist upon initialization.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
setAutoStartup(boolean) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setAutoStartup(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setAutoStartup(boolean) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setAutoStartup(boolean) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setBaseDirectory(String) - Method in class org.springframework.integration.store.PropertiesPersistingMetadataStore
 
setBasename(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set a single basename, following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
setBasenames(String[]) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set an array of basenames, each following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.MessagingTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
Specify a BeanFactory in order to enable resolution via @beanName in the expression.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setBeanName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setBeanName(String) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setBeanResolver(BeanResolver) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
setBufferSize(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setCacheLevelName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setCacheSeconds(int) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the number of seconds to cache loaded properties files.
setCaseSensitive(boolean) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Specify whether comparison of value returned by XPathExpression to test value should be case sensitive.
setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
setChannelIdentifierMap(Map<String, String>) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setChannelIdentifierMap(Map<String, String>) - Method in class org.springframework.integration.router.AbstractMessageRouter
Allows you to set the map which will map channel identifiers to channel names.
setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setChannelMapping(String, String) - Method in class org.springframework.integration.router.AbstractMessageRouter
 
setChannelName(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.core.MessagingTemplate
Set the ChannelResolver that is to be used to resolve MessageChannel references for this template.
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Set the ChannelResolver to be used when there is no default output channel.
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify the ChannelResolver strategy to use.
setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the channels for this router.
setCharset(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setCharset(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the charset name to use when writing a File from a String-based Message payload.
setCharset(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setCharset(String) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
Set the charset name to use when copying the File to a String.
setCharset(Charset) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
Sets the character set used for writing form data.
setCharset(String) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify the charset name to use for converting String-typed payloads to bytes.
setCharset(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
setCharset(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setCharset(String) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
Specify the name of the Charset to use when converting from bytes.
setCipherSuites(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setClientId(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setClientMode(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
ACTIVE_LOCAL_DATA_CONNECTION_MODE = 0
A constant indicating the FTP session is expecting all transfers to occur between the client (local) and server and that the server should connect to the client's data port to initiate a data transfer.
setClientVersion(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setComparator(Comparator<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
A comparator to use to order messages before processing.
setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setComponentName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Sets the name of this component.
setComponentName(String) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setComponentName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setComponentNamePatterns(String[]) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setComponentNamePatterns(String[]) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
setComponentType(String) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setConcurrency(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConfig(FTPClientConfig) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
 
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
Sets the client or server connection factory; for this (an inbound adapter), if the factory is a client connection factory, the sockets are owned by a sending channel adapter and this adapter is used to receive replies.
setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
Sets the client or server connection factory; for this (an outbound adapter), if the factory is a server connection factory, the sockets are owned by a receiving channel adapter and this adapter is used to send replies.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS ConnectionFactory that this gateway should use.
setContainerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setConversionService(ConversionService) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the ConversionService to use when trying to convert to one of this channel's supported datatypes for a Message whose payload does not already match.
setConversionService(ConversionService) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setConversionService(ConversionService) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
Specify the converter to use.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.XPathRouter
Specify the Converter to use when converting payloads prior to XPath evaluation.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
Specify the converter used to convert payloads prior to XPath testing.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
Specify the Converter to use when converting payloads prior to validation.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Specify the XmlPayloadConverter to use when converting a Message payload prior to XPath evaluation.
setConvertExceptions(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
Flag to determine if conversion and writing out of message handling exceptions should be attempted (default false, in which case they will simply be re-thrown).
setCorrelationId(Object) - Method in class org.springframework.integration.support.MessageBuilder
 
setCorrelationKey(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide the name of a JMS property that should be copied from the request Message to the reply Message.
setCorrelationKey(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide the name of a JMS property that should hold a generated UUID that the receiver of the JMS Message would expect to represent the CorrelationID.
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the CorrelationStrategy to be used to determine the correlation key for incoming messages
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setCreatedAt(Date) - Method in class org.springframework.integration.twitter.core.Tweet
 
setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Sets a GroovyObjectCustomizer for this processor.
setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
Sets a GroovyObjectCustomizer for this processor.
setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
The JDBC DataSource to use when interacting with the database.
setDatatypes(Class<?>...) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the Message payload datatype(s) supported by this channel.
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
Set the default channel where Messages should be sent if the annotation itself does not provide a channel.
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.core.MessagingTemplate
Specify the default MessageChannel to use when invoking the send and/or receive methods that do not expect a channel parameter.
setDefaultDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the default delay in milliseconds.
setDefaultDomain(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
The JMX domain to use for MBeans registered.
setDefaultEncoding(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the default charset to use for parsing properties files.
setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setDefaultMultipartCharset(String) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
Specify the default charset name to use when converting multipart file content into Strings if the multipart itself does not provide a charset.
setDefaultNotificationType(String) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Specify a dot-delimited String representing the Notification type to use by default when no explicit Notification mapper has been configured.
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the default channel where Messages should be sent if channel resolution fails to return any channels.
setDefaultOverwrite(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setDefaultReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default reply channel.
setDefaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the default reply destination to send reply messages to.
setDefaultReplyQueueName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply queue to send reply messages to.
setDefaultReplyTimeout(long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for receiving reply messages.
setDefaultReplyTopicName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply topic to send reply messages to.
setDefaultRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel.
setDefaultRequestTimeout(long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for sending request messages.
setDelayHeaderName(String) - Method in class org.springframework.integration.handler.DelayHandler
Specify the name of the header that should be checked for a delay period (in milliseconds) or a Date to delay until.
setDeleteFiles(boolean) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
Specify whether to delete the File after transformation.
setDeleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setDeleteSourceFiles(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDeleteSourceFiles(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to delete source Files after writing to the destination directory.
setDelimiters(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setDelimiters(String) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
Set delimiters to use for tokenizing String values.
setDeliveryMode(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the JMS DeliveryMode to use when sending request Messages.
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set whether message delivery should be persistent or non-persistent, specified as a boolean value ("true" or "false").
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
setDeserializer(Deserializer<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A converter for deserializing byte arrays to messages.
setDeserializer(Deserializer<Object>) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
setDestination(Destination) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestination(Destination) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setDestination(Destination) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setDestinationName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestinationName(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setDestinationName(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the DestinationResolver that should be used to resolve reply destination names for this listener.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide the DestinationResolver to use when resolving either a 'requestDestinationName' or 'replyDestinationName' value.
setDirectory(File) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setDirectory(File) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDirectory(File) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify the input directory.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.filter.MessageFilter
Specify a channel where rejected Messages should be sent.
setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setDurableSubscriptionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setEnableDaemonThread(Boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setErrorChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorCode(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The error code to use to signal an error in the message handling.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Provide an ErrorHandler strategy for handling Exceptions that occur downstream from this channel.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setErrorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the ResponseErrorHandler for the underlying RestTemplate.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setErrorsKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
The key used to expose Errors in the core, in the case that message handling fails.
setEvaluateAsString(boolean) - Method in class org.springframework.integration.xml.router.XPathRouter
 
setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Specify the expected XPathEvaluationType.
setEventTypes(Class<? extends ApplicationEvent>[]) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
Set the list of event types (classes that extend ApplicationEvent) that this adapter should send to the message channel.
setExceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setExecutor(Executor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify the expected response type for the REST request.
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Set the result type expected from evaluation of the expression.
setExpectReply(boolean) - Method in class org.springframework.integration.gateway.RemotingInboundGatewaySupport
Deprecated. Specify whether the gateway should be expected to return a reply.
setExpectReply(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify whether a reply Message is expected.
setExpectReply(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether a JMS reply Message is expected.
setExpirationDate(Long) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpireOnDestroy(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Flag to indicate that the stores should be expired when this component is destroyed (i.e.
setExpiryCallbacks(Collection<MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Convenient injection point for expiry callbacks in the message store.
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether explicit QoS settings are enabled (deliveryMode, priority, and timeToLive).
setExplicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether explicit QoS should be enabled for replies (for timeToLive, priority, and deliveryMode settings).
setExposeListenerSession(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setExpression(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
Specify an expression to be evaluated against the Message in order to generate a file name.
setExpression(String) - Method in class org.springframework.integration.handler.LoggingHandler
 
setExtractPayload(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify whether the outbound message's payload should be extracted when preparing the request body.
setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify whether the payload should be extracted from each integration Message to be used as the JMS Message body.
setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
setExtractPayload(boolean) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
Specify whether the source Message's payload should be extracted prior to marshalling.
setExtractPayload(boolean) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
Specify whether the text message body should be extracted when mapping to a Spring Integration Message payload.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the Spring Integration reply Message's payload should be extracted prior to converting into a JMS Message.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property describes what to do with a JMS reply Message.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the JMS request Message's body should be extracted prior to converting into a Spring Integration Message.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property describes how a JMS Message should be generated from the Spring Integration Message.
setFailedMessage(Message<?>) - Method in exception org.springframework.integration.MessagingException
 
setFailover(boolean) - Method in class org.springframework.integration.channel.DirectChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.channel.ExecutorChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Specify whether this dispatcher should failover when a single MessageHandler throws an Exception.
setFallbackToSystemLocale(boolean) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set whether to fall back to the system Locale if no files for a specific Locale have been found.
setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setFileEncodings(Properties) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set per-file charsets to use for parsing properties files.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Provide the FileNameGenerator strategy to use when generating the destination file's name.
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setFilenamePattern(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFilenameRegex(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFileType(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
File types defined by FTP constants: FTP.ASCII_FILE_TYPE FTP.EBCDIC_FILE_TYPE FTP.BINARY_FILE_TYPE (DEFAULT) FTP.LOCAL_FILE_TYPE
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
setFilter(FileListFilter<File>) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom filter to be used by this scanner.
setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
Sets a FileListFilter.
setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setFilter(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a NotificationFilter to be passed to the server when registering this listener.
setFromUser(String) - Method in class org.springframework.integration.twitter.core.Tweet
 
setFromUserId(long) - Method in class org.springframework.integration.twitter.core.Tweet
 
setHandback(Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a handback object to provide context to the listener upon notification.
setHandler(MessageHandler) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setHeader(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name.
setHeaderExpressionMap(Map<String, Map<String, String>>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setHeaderExpressions(Map<String, String>) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a JmsHeaderMapper implementation to use when converting between JMS Messages and Spring Integration Messages.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a JmsHeaderMapper implementation for mapping the Spring Integration Message Headers to/from JMS Message properties.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setHeaderMapper(HeaderMapper<SoapHeader>) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
setHeaderName(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
Specify a custom header name to check for the file name.
setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
setHost(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setHost(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setHost(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setHostKeyAlias(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setHttpMethod(HttpMethod) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Specify the HttpMethod for requests.
setId(long) - Method in class org.springframework.integration.twitter.core.Tweet
 
setIdleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setIgnoreChannelNameResolutionFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setIgnoreChannelNameResolutionFailures(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether this router should ignore any failure to resolve a channel name to an actual MessageChannel instance when delegating to the ChannelResolver strategy.
setIgnoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Specify whether empty String response payloads should be ignored.
setIgnoreFailures(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreFailures(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreSendFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setIgnoreSendFailures(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether send failures for one or more of the recipients should be ignored.
setImplicit(boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setInboundHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide the header names that should be mapped from an HTTP request (for inbound adapters) or HTTP response (for outbound adapters) to a Spring Integration Message's headers.
setInboundHeaderNames(String[]) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
setInboundMessageMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setInboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Specify a prefix to be appended to the integration message header name for any JMS property that is being mapped into the MessageHeaders.
setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setInterceptors(TcpConnectionInterceptorFactory[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setInterceptors(ClientInterceptor[]) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setJavaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Optional, sets the Authenticator to be used to obtain a session.
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.AbstractMailReceiver
A new Session will be created with these properties (and the JavaMailAuthenticator if provided).
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
The JdbcOperations to use when interacting with the database.
setKeyManager(KeyManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
Flag to indicate that the update query is an insert with autogenerated keys, which will be logged at debug level.
setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
Flag to indicate that the update query is an insert with autogenerated keys, which will be logged at debug level.
setKnownHosts(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setLanguageCode(String) - Method in class org.springframework.integration.twitter.core.Tweet
 
setLastRead(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Provide a LoadBalancingStrategy for this dispatcher.
setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Override the LobHandler that is used to create and unpack large objects in SQL queries.
setLocalAddress(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setLocalAddress(String) - Method in interface org.springframework.integration.ip.CommonSocketOptions
On a multi-homed system, specifies the ip address of the network interface used to communicate.
setLocalAddress(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setLocalAddress(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
Used on multi-homed systems to enforce the server to listen on a specfic network address instead of all network adapters.
setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
 
setLocker(AbstractFileLockerFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setLocker(FileLocker) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Sets a custom locker to be used by this scanner.
setLocker(FileLocker) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom locker to be used by this scanner.
setLocker(FileLocker) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setLoggerName(String) - Method in class org.springframework.integration.handler.LoggingHandler
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
If true, DNS reverse lookup is done on the remote ip address.
setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
setMapper(TcpMessageMapper) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
setMapToPayload(boolean) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
setMaxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Specify the maximum number of Messages to fetch per call to AbstractMailReceiver.receive().
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setMaxMessageSize(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
The maximum supported message size for this serializer.
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
Set the maximum number of messages to receive for each poll.
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMaxRowsPerPoll(int) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setMaxRowsPerPoll(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
The maximum number of rows to pull out of the query results per poll (if greater than zero, otherwise all rows will be packed into the outgoing message).
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.core.MessagingTemplate
Set the MessageConverter that is to be used to convert between Messages and objects for this template.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a MessageConverter implementation to use when converting between JMS Messages and Spring Integration Messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a MessageConverter strategy to use for converting the Spring Integration request Message into a JMS Message and for converting the JMS reply Messages back into Spring Integration Messages.
setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set a list of HttpMessageConverters to be used by the underlying RestTemplate.
setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
A message group store to expire according the the other configurations.
setMessageIdEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageProcessor(MessageProcessor<T>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setMessageSelector(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMessageSelector(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Specify a JMS Message Selector expression to use when receiving Messages.
setMessageSender(WebServiceMessageSender) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageSenders(WebServiceMessageSender[]) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setMessageStore(MessageStore) - Method in class org.springframework.integration.handler.DelayHandler
Specify the MessageStore that should be used to store Messages while awaiting the delay.
setMessageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setMetadataStore(MetadataStore) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
 
setMethod(Method) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMethodMetadataMap(Map<String, GatewayMethodMetadata>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMinAcksForSuccess(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
If acknowledge = true; how many acks needed for success.
setMultipartFileReader(MultipartFileReader<?>) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
Specify the MultipartFileReader to use when reading MultipartFile content.
setName(String) - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
setName(String) - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
setNeedClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setNodeMapper(NodeMapper) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
Set a NodeMapper to use for generating the result object.
setNotificationMapper(OutboundMessageMapper<Notification>) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Set a mapper for creating Notifications from a Message.
setObject(Object) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonOutboundMessageMapper
 
setObjectName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the String value of the JMX MBean's ObjectName.
setObjectName(ObjectName) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify the JMX ObjectName of the notification publisher to which this notification listener should be subscribed.
setObjectName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify a default ObjectName to use when no such header is available on the Message being handled.
setObjectNameStaticProperties(Map<String, String>) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
Static properties that will be added to all object names.
setOperationName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify an operation name to be invoked when no such header is available on the Message being handled.
setOrder(int) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setOrder(Integer) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setOrder(int) - Method in interface org.springframework.integration.context.Orderable
Set the order for this component.
setOrder(Integer) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setOrder(int) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setOrder(int) - Method in class org.springframework.integration.handler.DelayHandler
 
setOrder(int) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setOutboundHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Provide the header names that should be mapped to an HTTP request (for outbound adapters) or HTTP response (for inbound adapters) from a Spring Integration Message's headers.
setOutboundHeaderNames(String[]) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
setOutboundMessageMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setOutboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
Specify a prefix to be appended to the JMS property name for any integration message header that is being mapped into the JMS Message.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setOutputChannel(MessageChannel) - Method in interface org.springframework.integration.core.MessageProducer
Specify the MessageChannel to which produced Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the MessageChannel where Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.DelayHandler
Set the output channel for this handler.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setOutputProperties(Properties) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
setParameterExpressions(Map<String, String>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Optionally maps parameter names to explicit expressions.
setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
setPassword(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setPassword(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setPassword(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setPattern(Pattern) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
setPattern(String) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
 
setPatternMatch(boolean) - Method in class org.springframework.integration.transformer.HeaderFilter
 
setPatterns(String[]) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setPayloadExpression(String) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
Provide an expression to be evaluated against the received ApplicationEvent instance (the "root object") in order to create the Message payload.
setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setPhase(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setPhase(int) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Deprecated. As of release 2.0.2, use individual setters
setPoolSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setPoolSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setPort(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setPort(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setPort(int) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setPrefix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Specify the prefix to use for temporary files.
setPrefix(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify a prefix to be added to each channel name prior to resolution.
setPreventDuplicates(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setPriority(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the JMS priority to use when sending request Messages.
setPriority(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setPrivateKey(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setPrivateKeyPassphrase(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setProfileImageUrl(String) - Method in class org.springframework.integration.twitter.core.Tweet
 
setPropertiesPersister(PropertiesPersister) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the PropertiesPersister to use for parsing properties files.
setProt(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProtocol(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProtocol(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setProtocol(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setProtocols(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setProxy(Proxy) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setPublisherMetadataSource(PublisherMetadataSource) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setPubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setQuery(String) - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
 
setQueueSize(Integer) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setReceiveTimeout(long) - Method in class org.springframework.integration.core.MessagingTemplate
Specify the timeout value to use for receive operations.
setReceiveTimeout(long) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the max timeout value for the MessageConsumer's receive call when waiting for a reply.
setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setRecipients(List<RecipientListRouter.Recipient>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the recipients for this router.
setRecoveryInterval(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setRegion(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A unique grouping identifier for all messages persisted with this store.
setRegistryHost(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setRegistryPort(int) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
Flag that determines if partial sequences are allowed.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the ReleaseStrategy that should be used when deciding if a group in this barrier may be released.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setReliabilityAttributes(boolean, boolean, String, int, int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Specify the full path to the remote directory.
setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setRemoveMessage(boolean) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.AbstractRemotingOutboundGateway
Deprecated.  
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setReplyChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the delivery mode for JMS reply Messages.
setReplyDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination from which reply Messages should be received.
setReplyDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination from which reply Messages should be received.
setReplyKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Specify the key to be used when adding the reply Message or payload to the core map (will be payload only unless the value of HttpRequestHandlingEndpointSupport.setExtractReplyPayload(boolean) is false).
setReplyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an OutboundMessageMapper for mapping to objects from any reply Messages received in receive or sendAndReceive operations.
setReplyPriority(int) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the priority value for JMS reply Messages.
setReplyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether the reply destination is a Topic.
setReplySqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for receiving reply messages.
setReplyTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setReplyTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setReplyTimeout(long) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setReplyTimeToLive(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the time-to-live property for JMS reply Messages.
setRequestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the request channel.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Specify the request channel where messages will be sent.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
Deprecated. 
setRequestDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination to which request Messages should be sent.
setRequestDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination to which request Messages should be sent.
setRequestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the ClientHttpRequestFactory for the underlying RestTemplate.
setRequestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an InboundMessageMapper for creating request Messages from any object passed in a send or sendAndReceive operation.
setRequestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether the request destination is a Topic.
setRequestSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for sending request messages.
setRequestTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
setRequestTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setRequestTimeout(long) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Flag wether reply is required.
setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set whether this router should always be required to resolve at least one channel.
setResource(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the ResourceLoader to use for loading bundle properties files.
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
 
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Sets the ResultFactory
setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setScanEachPoll(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanEachPoll(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optionally specify a custom scanner, for example the RecursiveLeafOnlyDirectoryScanner
setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
Initialize the selector chain.
setSelectSqlParameterSource(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
A source of parameters for the select query used for polling.
setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setSendTimeout(long) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setSendTimeout(long) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.core.MessagingTemplate
Specify the timeout value to use for send operations.
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the maximum time to wait for a Message to be sent to the output channel.
setSendTimeout(Long) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Set the timeout for sending reply Messages.
setSendTimeout(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the timeout for sending reply Messages.
setSendTimeout(long) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setSequenceNumber(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
setSerializer(Serializer<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A converter for serializing messages to byte arrays for storage.
setSerializer(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Provide the MBeanServer where the JMX MBean has been registered.
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Provide a reference to the MBeanServer where the notification publishing MBeans are registered.
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Provide a reference to the MBeanServer within which the MBean target for operation invocation has been registered.
setServerAliveCountMax(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setServerAliveInterval(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the interface class that the generated proxy should implement.
setSession(Session) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Set the Session.
setSession(Session) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSessionConfig(Properties) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setSessionCreation(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setSessionTransacted(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
setShouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Specify whether mail messages should be deleted after retrieval.
setShouldDeleteMessages(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setShouldExtractPayload(boolean) - Method in class org.springframework.integration.json.JsonOutboundMessageMapper
 
setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
Specify whether to log the full Message.
setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.ImapMailReceiver
Specify if messages should be marked as read.
setShouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
Specify whether the IDLE task should reconnect automatically after catching a FolderClosedException while waiting for messages.
setShouldSkipNulls(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
Specify whether null values, such as might be returned from an expression evaluation, should be skipped.
setShouldTrack(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify whether this component should be tracked in the Message History.
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Specify whether this gateway should be tracked in the Message History of Messages that originate from its send or sendAndReceive operations.
setShouldTrack(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setShouldTrack(boolean) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setShouldTrack(boolean) - Method in interface org.springframework.integration.history.TrackableComponent
 
setShouldTrack(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
setShouldTrack(boolean) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setSingleUse(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
If true, sockets created by this factory will be used once.
setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
 
setSingleUse(boolean) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
When true, the socket is used once and discarded.
setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Sets socket attributes on the socket.
setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketFactory(SocketFactory) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoLinger(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoReceiveBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoSendBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoTimeout(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the source to be polled for Messages.
setSource(String) - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
setSource(String) - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
setSource(String) - Method in class org.springframework.integration.twitter.core.Tweet
 
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
Provide the SourceFactory to be used.
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Sets the SourceFactory.
setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters can be added (default is empty).
setStaticParameters(Map<String, ?>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
Define some static parameter values.
setStoreLock(Object) - Method in class org.springframework.integration.store.MessageGroupQueue
 
setStoreUri(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setStringToBytes(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
Sets whether outbound String payloads are to be converted to byte[].
setSubscriptionDurable(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setSubscriptionMode(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setSuffix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
Specify the suffix to use for temporary files.
setSuffix(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify a suffix to be added to each channel name prior to resolution.
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Public setter for the table prefix property.
setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
Deprecated. As of release 2.0.5
setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setTemporaryDirectory(File) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
 
setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
setText(String) - Method in class org.springframework.integration.twitter.core.Tweet
 
setTheConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionInterceptor
Sets the underlying connection (or next interceptor)
setTheConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptor
 
setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.filter.MessageFilter
Specify whether this filter should throw a MessageRejectedException when its selector does not accept a Message.
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
 
setTimeout(long) - Method in class org.springframework.integration.channel.interceptor.WireTap
Specify the timeout value for sending to the intercepting target.
setTimeout(Long) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the timeout for sending a message to the resolved channel.
setTimeout(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Timeout in milliseconds (default -1).
setTimeToLive(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Set the underlying MulticastSocket time to live property.
setTimeToLive(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the timeToLive for each sent Message.
setToUserId(Long) - Method in class org.springframework.integration.twitter.core.Tweet
 
setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransactionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransactionTimeout(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
setTransformOnSend(boolean) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
setTrigger(Trigger) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTrigger(Trigger) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTrustManager(TrustManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setType(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setUpdatePerRow(boolean) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUpdateSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUriVariableExpressions(Map<String, String>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
setUseClientMode(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setUser(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
setUser(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
setUserDefinedHeaderPrefix(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Sets the prefix to use with user-defined (non-standard) headers.
setUsername(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
When set to true, connections created by this factory attempt to use direct buffers where possible.
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
If true, connection will attempt to use direct buffers where possible.
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
setUsingNio(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setViewName(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
Specify the view name.
setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
Specify the voting strategy for this selector chain.
setWaitForTasksToCompleteOnShutdown(boolean) - Method in class org.springframework.integration.handler.DelayHandler
Set whether to wait for scheduled tasks to complete on shutdown.
setWantsClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
 
setXmlPayloadConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setXslParameterMappings(Map<String, Expression>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setXsltParamHeaders(String[]) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
SftpInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
Parser for 'sftp:inbound-channel-adapter'
SftpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
SftpInboundFileSynchronizer - Class in org.springframework.integration.sftp.inbound
Handles the synchronization between a remote SFTP directory and a local mount.
SftpInboundFileSynchronizer(SessionFactory) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
SftpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.sftp.inbound
A MessageSource implementation for SFTP that delegates to an InboundFileSynchronizer.
SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
SftpNamespaceHandler - Class in org.springframework.integration.sftp.config
Provides namespace support for using SFTP.
SftpNamespaceHandler() - Constructor for class org.springframework.integration.sftp.config.SftpNamespaceHandler
 
SftpRegexPatternFileListFilter - Class in org.springframework.integration.sftp.filters
Implementation of AbstractRegexPatternFileListFilter for SFTP.
SftpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
SftpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
SftpSimplePatternFileListFilter - Class in org.springframework.integration.sftp.filters
Implementation of AbstractSimplePatternFileListFilter for SFTP.
SftpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.filter.MessageFilter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Subclasses may override this.
shouldCopyRequestHeaders() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
shouldCreateEndpoint(T) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
shouldDeleteMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Indicates whether the mail messages should be deleted after being received.
shouldGenerateId() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
shouldGenerateId() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.GatewayParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
shutDown() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
 
SimpleMessageConverter - Class in org.springframework.integration.support.converter
 
SimpleMessageConverter() - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageGroup - Class in org.springframework.integration.store
Represents a mutable group of correlated messages that is bound to a certain MessageStore and group id.
SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Collection<? extends Message<?>>, Object, long) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageHandlerMetrics - Class in org.springframework.integration.monitor
 
SimpleMessageHandlerMetrics(MessageHandler) - Constructor for class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
SimpleMessageSourceMetrics - Class in org.springframework.integration.monitor
 
SimpleMessageSourceMetrics(MessageSource<?>) - Constructor for class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
SimpleMessageStore - Class in org.springframework.integration.store
Map-based implementation of MessageStore and MessageGroupStore.
SimpleMessageStore(int, int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity, or unlimited size if the given capacity is less than 1.
SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with unlimited capacity
SimpleMetadataStore - Class in org.springframework.integration.store
Simple implementation of MetadataStore that uses an in-memory map only.
SimpleMetadataStore() - Constructor for class org.springframework.integration.store.SimpleMetadataStore
 
SimpleMultipartFileReader - Class in org.springframework.integration.http.multipart
MultipartFileReader implementation that does not maintain metadata from the original MultipartFile instance.
SimpleMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.SimpleMultipartFileReader
 
SimplePatternFileListFilter - Class in org.springframework.integration.file.filters
Filter that supports ant style path expressions, which are less powerful but more readable than regular expressions.
SimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.SimplePatternFileListFilter
 
SimplePublisherMetadataSource - Class in org.springframework.integration.aop
Simple implementation of PublisherMetadataSource that allows for configuration of a single channel name, payload expression, and array of header key=value expressions.
SimplePublisherMetadataSource() - Constructor for class org.springframework.integration.aop.SimplePublisherMetadataSource
 
SimpleWebServiceInboundGateway - Class in org.springframework.integration.ws
 
SimpleWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
SimpleWebServiceOutboundGateway - Class in org.springframework.integration.ws
An outbound Messaging Gateway for invoking a Web Service.
SimpleWebServiceOutboundGateway(DestinationProvider) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
singleUse - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
singleUse - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
singleUse - Variable in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnection
 
size() - Method in class org.springframework.integration.history.MessageHistory
 
size() - Method in class org.springframework.integration.MessageHeaders
 
size() - Method in interface org.springframework.integration.store.MessageGroup
 
size() - Method in class org.springframework.integration.store.MessageGroupQueue
 
size() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
socket - Variable in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
socket - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
SoftEndOfStreamException - Exception in org.springframework.integration.ip.tcp.serializer
Used to communicate that a stream has closed, but between logical messages.
SoftEndOfStreamException() - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
 
SoftEndOfStreamException(String) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
soSendBufferSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
soSendBufferSize - Variable in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
soTimeout - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
soTimeout - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
soTimeout - Variable in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
soTimeout - Variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
SourceCreatingTransformer - Class in org.springframework.integration.xml.transformer
Transforms the payload to a Source using a SourceFactory.
SourceCreatingTransformer() - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
SourceCreatingTransformer(SourceFactory) - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
SourceFactory - Interface in org.springframework.integration.xml.source
Factory to create a Source possibly taking into account the provided message payload instance.
SourcePollingChannelAdapter - Class in org.springframework.integration.endpoint
A Channel Adapter implementation for connecting a MessageSource to a MessageChannel.
SourcePollingChannelAdapter() - Constructor for class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
SourcePollingChannelAdapterFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating a SourcePollingChannelAdapter instance.
SourcePollingChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Subclasses must override this method to split the received Message.
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
 
splitMessage(Message<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
Splitter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of splitting a single message or message payload to produce multiple messages or payloads.
SplitterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Splitter.
SplitterAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
 
SplitterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Splitter.
SplitterFactoryBean() - Constructor for class org.springframework.integration.config.SplitterFactoryBean
 
SplitterParser - Class in org.springframework.integration.config.xml
Parser for the <splitter/> element.
SplitterParser() - Constructor for class org.springframework.integration.config.xml.SplitterParser
 
SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
Collaborator for JDBC adapters which allows creation of instances of SqlParameterSource for use in update operations.
StandardHeaderEnricherParser - Class in org.springframework.integration.config.xml
Parser for the <header-enricher> element within the core integration namespace.
StandardHeaderEnricherParser() - Constructor for class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
start() - Method in class org.springframework.integration.channel.interceptor.WireTap
Restart the wire tap if it has been stopped.
start() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
start() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
start() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
start() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
start() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
start() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Starts the listening process.
start() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
start() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
start() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
start() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
start() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
start() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
start() - Method in class org.springframework.integration.monitor.ManagedEndpoint
 
start() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
start() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
start() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
Statistics - Class in org.springframework.integration.monitor
 
Statistics(int, double, double, double, double) - Constructor for class org.springframework.integration.monitor.Statistics
 
STATUS_CODE - Static variable in class org.springframework.integration.http.HttpHeaders
 
StatusUpdatingMessageHandler - Class in org.springframework.integration.twitter.outbound
MessageHandler for sending regular status updates as well as 'replies' or 'mentions'.
StatusUpdatingMessageHandler(TwitterOperations) - Constructor for class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
 
stderr() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the default charset encoding.
stderr(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the specified charset encoding.
stdin() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
stdout() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the default charset encoding.
stdout(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the specified charset encoding.
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
stop() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop(Runnable) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
stop() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Stops the server.
stop(Runnable) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
stop() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
stop() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
stop() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
stop(Runnable) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
stop() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
stop(Runnable) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
stop() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
 
stop() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
 
stop() - Method in class org.springframework.integration.monitor.ManagedEndpoint
 
stop() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop(Runnable) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
stop(Runnable) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
stop() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
StreamNamespaceHandler - Class in org.springframework.integration.stream.config
 
StreamNamespaceHandler() - Constructor for class org.springframework.integration.stream.config.StreamNamespaceHandler
 
StringResultFactory - Class in org.springframework.integration.xml.result
 
StringResultFactory() - Constructor for class org.springframework.integration.xml.result.StringResultFactory
 
StringSourceFactory - Class in org.springframework.integration.xml.source
SourceFactory implementation which supports creation of a StringSource from a Document, File or String payload
StringSourceFactory() - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringSourceFactory(TransformerFactory) - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringValueTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
XPath MessageSelector that tests if a provided value supports payloads of type Document or String.
StringValueTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Create a selector which tests for the given value and supports multiple namespaces.
StringValueTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a single namespace Xpath selector.
StringValueTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a non-namespaced testing selector.
StringValueTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a selector with the provided XPathExpression.
STX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
 
subList(int, int) - Method in class org.springframework.integration.history.MessageHistory
 
SubscribableChannel - Interface in org.springframework.integration.core
Interface for any MessageChannel implementation that accepts subscribers.
SubscribableJmsChannel - Class in org.springframework.integration.jms
 
SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
subscribe(MessageHandler) - Method in interface org.springframework.integration.core.SubscribableChannel
Register a MessageHandler as a subscriber to this channel.
subscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
success() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
Add a new event with successful outcome.
suggestedClassName() - Method in class org.springframework.integration.groovy.config.RefreshableResourceScriptSource
 
supports(Class<?>) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
supports(Class<?>) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
 
synchronizeToLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
synchronizeToLocalDirectory(File) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
 

T

take() - Method in class org.springframework.integration.store.MessageGroupQueue
 
TASK_SCHEDULER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
taskExecutor - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
taskExecutor - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
TcpConnection - Interface in org.springframework.integration.ip.tcp.connection
An abstraction over Socket and SocketChannel that sends Message objects by serializing the payload and streaming it to the destination.
TcpConnectionFactoryFactoryBean - Class in org.springframework.integration.ip.config
Instantiates a TcpN(et|io)(Server|Client)ConnectionFactory, depending on type and using-nio attributes.
TcpConnectionFactoryFactoryBean() - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
 
TcpConnectionInterceptor - Interface in org.springframework.integration.ip.tcp.connection
 
TcpConnectionInterceptorFactory - Interface in org.springframework.integration.ip.tcp.connection
Interface for TCP connection interceptor factories.
TcpConnectionInterceptorFactoryChain - Class in org.springframework.integration.ip.tcp.connection
 
TcpConnectionInterceptorFactoryChain() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
 
TcpConnectionParser - Class in org.springframework.integration.ip.config
 
TcpConnectionParser() - Constructor for class org.springframework.integration.ip.config.TcpConnectionParser
 
TcpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
Channel Adapter that receives UDP datagram packets and maps them to Messages.
TcpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
 
TcpInboundGateway - Class in org.springframework.integration.ip.tcp
Inbound Gateway using a server connection factory - threading is controlled by the factory.
TcpInboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpInboundGateway
 
TcpInboundGatewayParser - Class in org.springframework.integration.ip.config
 
TcpInboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundGatewayParser
 
TcpListener - Interface in org.springframework.integration.ip.tcp.connection
Classes that implement this interface may register with a connection factory to receive messages retrieved from a TcpConnection
TcpMessageMapper - Class in org.springframework.integration.ip.tcp.connection
Maps incoming data from a TcpConnection to a Message.
TcpMessageMapper() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
TcpNetClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
A client connection factory that creates TcpNetConnections.
TcpNetClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
Creates a TcpNetClientConnectionFactory for connections to the host and port.
TcpNetConnection - Class in org.springframework.integration.ip.tcp.connection
A TcpConnection that uses and underlying Socket.
TcpNetConnection(Socket, boolean, boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetConnection
Constructs a TcpNetConnection for the socket.
TcpNetServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
Implements a server connection factory that produces TcpNetConnections using a ServerSocket.
TcpNetServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
Listens for incoming connections on the port.
TcpNioClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
A client connection factory that creates TcpNioConnections.
TcpNioClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
Creates a TcpNioClientConnectionFactory for connections to the host and port.
TcpNioConnection - Class in org.springframework.integration.ip.tcp.connection
A TcpConnection that uses and underlying SocketChannel.
TcpNioConnection(SocketChannel, boolean, boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioConnection
Constructs a TcpNetConnection for the SocketChannel.
TcpNioServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
/** Implements a server connection factory that produces TcpNioConnections using a ServerSocketChannel.
TcpNioServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
Listens for incoming connections on the port.
TcpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
 
TcpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundChannelAdapterParser
 
TcpOutboundGateway - Class in org.springframework.integration.ip.tcp
TCP outbound gateway that uses a client connection factory.
TcpOutboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
TcpOutboundGatewayParser - Class in org.springframework.integration.ip.config
Parser for the <outbound-gateway> element of the integration 'jms' namespace.
TcpOutboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundGatewayParser
 
TcpReceivingChannelAdapter - Class in org.springframework.integration.ip.tcp
Tcp inbound channel adapter using a TcpConnection to receive data - if the connection factory is a server factory, this Listener owns the connections.
TcpReceivingChannelAdapter() - Constructor for class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
TcpSender - Interface in org.springframework.integration.ip.tcp.connection
An interface representing a sending client of a connection factory.
TcpSendingMessageHandler - Class in org.springframework.integration.ip.tcp
Tcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections.
TcpSendingMessageHandler() - Constructor for class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
TestUtils - Class in org.springframework.integration.test.util
 
TestUtils() - Constructor for class org.springframework.integration.test.util.TestUtils
 
TestUtils.TestApplicationContext - Class in org.springframework.integration.test.util
 
theConnection - Variable in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
TimelineReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
This MessageSource lets Spring Integration consume given account's timeline as messages.
TimelineReceivingMessageSource(TwitterOperations) - Constructor for class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
 
TimeoutCountSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that releases all messages if any of the following is true: The sequence is complete (if there is one). There are more messages than a threshold set by the user. The time elapsed since the earliest message, according to their timestamps, exceeds a timeout set by the user.
TimeoutCountSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
TimeoutCountSequenceSizeReleaseStrategy(int, long) - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
TIMESTAMP - Static variable in class org.springframework.integration.jms.JmsHeaders
 
TIMESTAMP - Static variable in class org.springframework.integration.MessageHeaders
 
TIMESTAMP_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
timeToLive - Variable in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
 
TO - Static variable in class org.springframework.integration.mail.MailHeaders
 
toArray() - Method in class org.springframework.integration.history.MessageHistory
 
toArray(T[]) - Method in class org.springframework.integration.history.MessageHistory
 
toHeaders(HttpHeaders) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
Map from an HttpHeaders instance to integration MessageHeaders.
toHeaders(Message) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
 
toHeaders(T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
toHeaders(SoapHeader) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
toMessage(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
toMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
toMessage(String) - Method in class org.springframework.integration.json.JsonInboundMessageMapper
 
toMessage(T) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
 
toMessage(Object) - Method in interface org.springframework.integration.support.converter.MessageConverter
 
toMessage(Object) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
toPasswordProtectedString(URLName) - Static method in class org.springframework.integration.mail.MailTransportUtils
Returns a string representation of the given URLName, where the password has been protected.
toString() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
toString() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
toString() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
toString() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
toString() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
toString() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
toString() - Method in class org.springframework.integration.history.MessageHistory
 
toString() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
toString() - Method in class org.springframework.integration.message.GenericMessage
 
toString() - Method in class org.springframework.integration.MessageHeaders
 
toString() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
 
toString() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
 
toString() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
 
toString() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
 
toString() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
 
toString() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
 
toString() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
 
toString() - Method in class org.springframework.integration.monitor.Statistics
 
toString() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
toString() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
TrackableComponent - Interface in org.springframework.integration.history
 
transferTo(File) - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
transform(Message<?>) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderFilter
 
transform(Message<?>) - Method in interface org.springframework.integration.transformer.Transformer
 
Transformer - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of transforming a message, message header, or message payload.
Transformer - Interface in org.springframework.integration.transformer
Strategy interface for transforming a Message.
TransformerAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Transformer.
TransformerAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
 
TransformerFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Transformer.
TransformerFactoryBean() - Constructor for class org.springframework.integration.config.TransformerFactoryBean
 
TransformerParser - Class in org.springframework.integration.config.xml
Parser for the <transformer/> element.
TransformerParser() - Constructor for class org.springframework.integration.config.xml.TransformerParser
 
transformFile(File) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
Subclasses must implement this method to transform the File contents.
transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToByteArrayTransformer
 
transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
 
transformPayload(String) - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
 
transformPayload(Map<?, ?>) - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
transformPayload(byte[]) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
transformResult(Result) - Method in interface org.springframework.integration.xml.transformer.ResultTransformer
 
tryAcquire(long) - Method in class org.springframework.integration.util.UpperBound
Acquires a permit from the underlying semaphore if this UpperBound is bounded and returns true if it succeeds within the given timeout.
tryClaim(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Claim the file to process.
tryClaim(File) - Method in interface org.springframework.integration.file.DirectoryScanner
Claim the file to process.
Tweet - Class in org.springframework.integration.twitter.core
Represents a Twitter status update (e.g., a "tweet").
Tweet() - Constructor for class org.springframework.integration.twitter.core.Tweet
 
Twitter4jTemplate - Class in org.springframework.integration.twitter.core
Implementation of TwitterOperations that delegates to Twitter4J.
Twitter4jTemplate() - Constructor for class org.springframework.integration.twitter.core.Twitter4jTemplate
Used to construct this template to perform Twitter API calls that do not require authorization.
Twitter4jTemplate(String, String, String, String) - Constructor for class org.springframework.integration.twitter.core.Twitter4jTemplate
Used to construct this template with OAuth authentication/authorization to perform Twitter API calls that do require authorization (e.g., send/receive DirectMessage)
TwitterHeaders - Class in org.springframework.integration.twitter.core
Header keys used by the various Twitter adapters.
TwitterHeaders() - Constructor for class org.springframework.integration.twitter.core.TwitterHeaders
 
TwitterInboundChannelAdapterParser - Class in org.springframework.integration.twitter.config
Parser for inbound Twitter Channel Adapters.
TwitterInboundChannelAdapterParser() - Constructor for class org.springframework.integration.twitter.config.TwitterInboundChannelAdapterParser
 
TwitterNamespaceHandler - Class in org.springframework.integration.twitter.config
Namespace handler for the Twitter adapters.
TwitterNamespaceHandler() - Constructor for class org.springframework.integration.twitter.config.TwitterNamespaceHandler
 
TwitterOperationException - Exception in org.springframework.integration.twitter.core
 
TwitterOperationException() - Constructor for exception org.springframework.integration.twitter.core.TwitterOperationException
 
TwitterOperationException(String) - Constructor for exception org.springframework.integration.twitter.core.TwitterOperationException
 
TwitterOperationException(Throwable) - Constructor for exception org.springframework.integration.twitter.core.TwitterOperationException
 
TwitterOperationException(String, Throwable) - Constructor for exception org.springframework.integration.twitter.core.TwitterOperationException
 
TwitterOperations - Interface in org.springframework.integration.twitter.core
 
TwitterOutboundChannelAdapterParser - Class in org.springframework.integration.twitter.config
Parser for all outbound Twitter adapters
TwitterOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.twitter.config.TwitterOutboundChannelAdapterParser
 
TYPE - Static variable in class org.springframework.integration.jms.JmsHeaders
 
TYPE - Static variable in class org.springframework.integration.xmpp.XmppHeaders
 
TYPE_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 

U

UdpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
Channel Adapter that receives UDP datagram packets and maps them to Messages.
UdpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
 
UdpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
 
UdpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
 
UnexpiredMessageSelector - Class in org.springframework.integration.selector
A MessageSelector that accepts Messages that are not yet expired.
UnexpiredMessageSelector() - Constructor for class org.springframework.integration.selector.UnexpiredMessageSelector
 
UnicastingDispatcher - Class in org.springframework.integration.dispatcher
Implementation of MessageDispatcher that will attempt to send a Message to at most one of its handlers.
UnicastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UnicastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UnicastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
A channel adapter to receive incoming UDP packets.
UnicastReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Constructs a UnicastReceivingChannelAdapter that listens on the specified port.
UnicastReceivingChannelAdapter(int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
Constructs a UnicastReceivingChannelAdapter that listens for packets on the specified port.
UnicastSendingMessageHandler - Class in org.springframework.integration.ip.udp
A MessageHandler implementation that maps a Message into a UDP datagram packet and sends that to the specified host and port.
UnicastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Basic constructor; no reliability; no acknowledgment.
UnicastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Can used to add a length to each packet which can be checked at the destination.
UnicastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Add an acknowledgment request to packets.
UnicastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
Add a length and/or acknowledgment request to packets.
UniqueMethodFilter - Class in org.springframework.integration.util
 
UniqueMethodFilter(Class<?>) - Constructor for class org.springframework.integration.util.UniqueMethodFilter
 
unlock(File) - Method in interface org.springframework.integration.file.FileLocker
Unlocks the given file.
unlock(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
 
unmarked - Variable in class org.springframework.integration.store.SimpleMessageGroup
 
UnmarshallingTransformer - Class in org.springframework.integration.xml.transformer
An implementation of Transformer that delegates to an OXM Unmarshaller.
UnmarshallingTransformer(Unmarshaller) - Constructor for class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
UnmarshallingTransformerParser - Class in org.springframework.integration.xml.config
 
UnmarshallingTransformerParser() - Constructor for class org.springframework.integration.xml.config.UnmarshallingTransformerParser
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
unsubscribe(MessageHandler) - Method in interface org.springframework.integration.core.SubscribableChannel
Remove a MessageHandler from the subscribers of this channel.
unsubscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
updateStatus(String) - Method in class org.springframework.integration.twitter.core.Twitter4jTemplate
 
updateStatus(String) - Method in interface org.springframework.integration.twitter.core.TwitterOperations
Updates the user's status.
UploadedMultipartFile - Class in org.springframework.integration.http.multipart
A MultipartFile implementation that represents an uploaded File.
UploadedMultipartFile(File, long, String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
 
UploadedMultipartFile(byte[], String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
 
UpperBound - Class in org.springframework.integration.util
Thin wrapper around a Semaphore that allows to create a potentially unlimited upper bound to by used in buffers of messages (e.g.
UpperBound(int) - Constructor for class org.springframework.integration.util.UpperBound
Create an UpperBound with the given capacity.
USER_PRINCIPAL - Static variable in class org.springframework.integration.http.HttpHeaders
 
username - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
usingDirectBuffers - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
 
usingDirectBuffers - Variable in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
UUIDConverter - Class in org.springframework.integration.util
Utility to help generate UUID instances from generic objects.
UUIDConverter() - Constructor for class org.springframework.integration.util.UUIDConverter
 

V

valueOf(String) - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
Returns the enum constant of this type with the specified name.
values() - Method in class org.springframework.integration.MessageHeaders
 
values() - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForAck - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
If true adds headers to instruct receiving adapter to return an ack.
waitForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
This method is unique to the IMAP receiver and only works if IMAP IDLE is supported (see RFC 2177 for more detail).
WebServiceHeaderEnricherParser - Class in org.springframework.integration.ws.config
 
WebServiceHeaderEnricherParser() - Constructor for class org.springframework.integration.ws.config.WebServiceHeaderEnricherParser
 
WebServiceHeaders - Class in org.springframework.integration.ws
Pre-defined header names to be used when storing or retrieving Web Service properties to/from integration Message Headers.
WebServiceHeaders() - Constructor for class org.springframework.integration.ws.WebServiceHeaders
 
WebServiceInboundGatewayParser - Class in org.springframework.integration.ws.config
 
WebServiceInboundGatewayParser() - Constructor for class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
WebServiceOutboundGatewayParser - Class in org.springframework.integration.ws.config
Parser for the <outbound-gateway/> element in the 'ws' namespace.
WebServiceOutboundGatewayParser() - Constructor for class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
WireTap - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that publishes a copy of the intercepted message to a secondary target while still sending the original message to the main channel.
WireTap(MessageChannel) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with no MessageSelector.
WireTap(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with the provided MessageSelector.
WireTapParser - Class in org.springframework.integration.config.xml
Parser for the <wire-tap> element.
WireTapParser() - Constructor for class org.springframework.integration.config.xml.WireTapParser
 
withPayload(T) - Static method in class org.springframework.integration.support.MessageBuilder
Create a builder for a new Message instance with the provided payload.
wrapConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
write(InputStream, String) - Method in interface org.springframework.integration.file.remote.session.Session
 
write(Message<T>, NamedComponent) - Static method in class org.springframework.integration.history.MessageHistory
 
write(MultiValueMap<String, ?>, MediaType, HttpOutputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
writeHeader(OutputStream, int) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
Writes the header, according to the header format.
writeInternal(Serializable, HttpOutputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
 
WsNamespaceHandler - Class in org.springframework.integration.ws.config
 
WsNamespaceHandler() - Constructor for class org.springframework.integration.ws.config.WsNamespaceHandler
 

X

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

A B C D E F G H I J K L M N O P Q R S T U V W X