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

A

AbstractChannelFactory - Class in org.springframework.integration.channel.factory
Base class for ChannelFactory implementations.
AbstractChannelFactory() - Constructor for class org.springframework.integration.channel.factory.AbstractChannelFactory
 
AbstractChannelParser - Class in org.springframework.integration.channel.config
Base class for channel parsers.
AbstractChannelParser() - Constructor for class org.springframework.integration.channel.config.AbstractChannelParser
 
AbstractEndpoint - Class in org.springframework.integration.endpoint
Base class for MessageEndpoint implementations.
AbstractEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractEndpoint
 
AbstractFileMessageCreator<T> - Class in org.springframework.integration.adapter.file
Base class providing common behavior for file-based message creators.
AbstractFileMessageCreator() - Constructor for class org.springframework.integration.adapter.file.AbstractFileMessageCreator
 
AbstractJmsTemplateBasedAdapter - Class in org.springframework.integration.adapter.jms
Base class for adapters that delegate to a JmsTemplate.
AbstractJmsTemplateBasedAdapter(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
AbstractJmsTemplateBasedAdapter(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
AbstractJmsTemplateBasedAdapter(ConnectionFactory, String) - Constructor for class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
AbstractJmsTemplateBasedAdapter() - Constructor for class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
No-arg constructor provided for convenience when configuring with setters.
AbstractMailHeaderGenerator - Class in org.springframework.integration.adapter.mail
Base implementation for MailHeaderGenerators.
AbstractMailHeaderGenerator() - Constructor for class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
 
AbstractMessageChannel - Class in org.springframework.integration.channel
Base class for MessageChannel implementations providing common properties such as the channel name and DispatcherPolicy.
AbstractMessageChannel(DispatcherPolicy) - Constructor for class org.springframework.integration.channel.AbstractMessageChannel
Create a channel with the given dispatcher policy.
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
 
AbstractMessageHandlerAdapter - Class in org.springframework.integration.handler
An implementation of the MessageHandler interface that invokes the specified method and target object.
AbstractMessageHandlerAdapter() - Constructor for class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
AbstractMessageHandlerCreator - Class in org.springframework.integration.handler.config
Base class for handler creators that generate a MessageHandler adapter for the provided object and method.
AbstractMessageHandlerCreator() - Constructor for class org.springframework.integration.handler.config.AbstractMessageHandlerCreator
 
AbstractMessagingTaskScheduler - Class in org.springframework.integration.scheduling
Base class for MessagingTaskScheduler implementations.
AbstractMessagingTaskScheduler() - Constructor for class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
 
AbstractRemotingTargetAdapter - Class in org.springframework.integration.adapter
A base class for remoting target adapters.
AbstractRemotingTargetAdapter(String) - Constructor for class org.springframework.integration.adapter.AbstractRemotingTargetAdapter
 
AbstractRequestReplySourceAdapterParser - Class in org.springframework.integration.adapter.config
Base class for request-reply source adapter parsers.
AbstractRequestReplySourceAdapterParser() - Constructor for class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
 
AbstractRoutingMessageHandler - Class in org.springframework.integration.router
Base class for message router implementations.
AbstractRoutingMessageHandler() - Constructor for class org.springframework.integration.router.AbstractRoutingMessageHandler
 
AbstractTargetEndpointParser - Class in org.springframework.integration.config
Base class for target-endpoint and handler-endpoint parsers.
AbstractTargetEndpointParser() - Constructor for class org.springframework.integration.config.AbstractTargetEndpointParser
 
AbstractWebServiceTargetAdapter - Class in org.springframework.integration.ws.adapter
Base class for Web Service target channel adapters.
AbstractWebServiceTargetAdapter(URI) - Constructor for class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
AbstractWebServiceTargetAdapter.TypeCheckingSoapActionCallback - Class in org.springframework.integration.ws.adapter
 
AbstractWebServiceTargetAdapter.TypeCheckingSoapActionCallback(String) - Constructor for class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter.TypeCheckingSoapActionCallback
 
accept(Message<?>) - Method in interface org.springframework.integration.message.selector.MessageSelector
 
accept(Message<?>) - Method in class org.springframework.integration.message.selector.MessageSelectorChain
Pass the message through the selector chain.
accept(Message<?>) - Method in class org.springframework.integration.message.selector.PayloadTypeSelector
 
accept(Message<?>) - Method in class org.springframework.integration.message.selector.UnexpiredMessageSelector
 
acceptedTypes - Variable in class org.springframework.integration.message.selector.PayloadTypeSelector
 
ACKNOWLEDGE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
ACKNOWLEDGE_AUTO - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
ACKNOWLEDGE_CLIENT - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
ACKNOWLEDGE_DUPS_OK - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
ACKNOWLEDGE_TRANSACTED - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
activateEndpoint(MessageEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
activateEndpoints() - Method in class org.springframework.integration.bus.MessageBus
 
activateSubscription(MessageChannel, Target, Schedule) - Method in class org.springframework.integration.bus.MessageBus
 
activateTargetEndpoint(TargetEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
ADAPTER_PARSER_MAPPINGS_LOCATION - Static variable in class org.springframework.integration.config.IntegrationNamespaceHandler
 
add(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
add(MessageHandler) - Method in class org.springframework.integration.handler.MessageHandlerChain
Add a handler to the end of the chain.
add(int, MessageHandler) - Method in class org.springframework.integration.handler.MessageHandlerChain
Add a handler to the chain at the specified index.
add(MessageSelector) - Method in class org.springframework.integration.message.selector.MessageSelectorChain
Add a selector to the end of the chain.
add(int, MessageSelector) - Method in class org.springframework.integration.message.selector.MessageSelectorChain
Add a selector to the chain at the specified index.
addAndRelease(Message<?>) - Method in class org.springframework.integration.router.AggregationBarrier
Adds a message to the aggregation group and releases if complete.
addAndRelease(Message<?>) - Method in interface org.springframework.integration.router.MessageBarrier
 
addDrink(Drink) - Method in class org.springframework.integration.samples.cafe.DrinkOrder
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Add a channel interceptor to the end of the list.
addPostProcessors(ParserContext) - Method in class org.springframework.integration.config.MessageBusParser
Adds extra post-processors to the context, to inject the objects configured by the MessageBus
addTarget(Target) - Method in class org.springframework.integration.bus.SubscriptionManager
 
addTarget(Target, Schedule) - Method in class org.springframework.integration.bus.SubscriptionManager
 
advice - Variable in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
advisor - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.file.FileSource
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.mail.MailTarget
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
afterPropertiesSet() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
afterPropertiesSet() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
afterPropertiesSet() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.message.MethodInvokingSource
 
afterPropertiesSet() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
afterPropertiesSet() - Method in class org.springframework.integration.router.AggregatingMessageHandler
Initialize this handler.
aggregate(List<Message<?>>) - Method in interface org.springframework.integration.router.Aggregator
 
aggregate(List<Message<?>>) - Method in class org.springframework.integration.router.AggregatorAdapter
 
AggregatingMessageHandler - Class in org.springframework.integration.router
A MessageHandler implementation that waits for a complete group of Messages to arrive and then delegates to an Aggregator to combine them into a single Message.
AggregatingMessageHandler(Aggregator, ScheduledExecutorService) - Constructor for class org.springframework.integration.router.AggregatingMessageHandler
Create a handler that delegates to the provided aggregator to combine a group of messages into a single message.
AggregatingMessageHandler(Aggregator) - Constructor for class org.springframework.integration.router.AggregatingMessageHandler
 
AggregatingMessageHandler.ReaperTask - Class in org.springframework.integration.router
 
AggregatingMessageHandler.ReaperTask() - Constructor for class org.springframework.integration.router.AggregatingMessageHandler.ReaperTask
 
AggregationBarrier - Class in org.springframework.integration.router
MessageBarrier implementation for message aggregation.
AggregationBarrier(CompletionStrategy) - Constructor for class org.springframework.integration.router.AggregationBarrier
Create an AggregationBarrier with the given CompletionStrategy.
aggregationCompleted(Object, List<Message<?>>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
Aggregator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of aggregating messages.
aggregator - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
Aggregator - Interface in org.springframework.integration.router
Strategy interface for aggregating a list of Messages into a single Message.
AGGREGATOR_ELEMENT - Static variable in class org.springframework.integration.config.AggregatorParser
 
AggregatorAdapter - Class in org.springframework.integration.router
Aggregator adapter for methods annotated with @Aggregator and for 'aggregator' elements that include a 'method' attribute (e.g.
AggregatorAdapter(Object, Method) - Constructor for class org.springframework.integration.router.AggregatorAdapter
 
AggregatorAdapter(Object, String) - Constructor for class org.springframework.integration.router.AggregatorAdapter
 
AggregatorMessageHandlerCreator - Class in org.springframework.integration.router.config
Creates an AggregatorAdapter for methods that aggregate messages.
AggregatorMessageHandlerCreator(ChannelRegistry) - Constructor for class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
AggregatorParser - Class in org.springframework.integration.config
Parser for the aggregator element of the integration namespace.
AggregatorParser() - Constructor for class org.springframework.integration.config.AggregatorParser
 
AnnotationAwareMessagePublishingInterceptor - Class in org.springframework.integration.aop
MessagePublishingInterceptor that resolves the channel from the publisher annotation of the invoked method.
AnnotationAwareMessagePublishingInterceptor(Class<? extends Annotation>, String, ChannelRegistry) - Constructor for class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
AnnotationDrivenParser - Class in org.springframework.integration.config
Parser for the annotation-driven element of the integration namespace.
AnnotationDrivenParser() - Constructor for class org.springframework.integration.config.AnnotationDrivenParser
 
AnnotationMethodMessageMapper - Class in org.springframework.integration.handler.annotation
A MessageMapper implementation for annotated handler methods.
AnnotationMethodMessageMapper(Method) - Constructor for class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
AnnotationMethodMessageMapper.MethodParameterMetadata - Class in org.springframework.integration.handler.annotation
 
AnnotationMethodMessageMapper.MethodParameterMetadata(Class<?>, String, boolean) - Constructor for class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper.MethodParameterMetadata
 
applicationEventPublisher - Variable in class org.springframework.integration.adapter.event.ApplicationEventTarget
 
ApplicationEventSource - Class in org.springframework.integration.adapter.event
A message source for passing Spring ApplicationEvents within messages.
ApplicationEventSource(MessageChannel) - Constructor for class org.springframework.integration.adapter.event.ApplicationEventSource
 
ApplicationEventTarget<T> - Class in org.springframework.integration.adapter.event
A message target for publishing MessagingEvents.
ApplicationEventTarget() - Constructor for class org.springframework.integration.adapter.event.ApplicationEventTarget
 
assertMethodReturnsBoolean() - Method in class org.springframework.integration.router.CompletionStrategyAdapter
 
attachmentFilename - Variable in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
attributes - Variable in class org.springframework.integration.message.MessageHeader
 
autoCreateChannels - Variable in class org.springframework.integration.bus.MessageBus
 
autoStartup - Variable in class org.springframework.integration.bus.MessageBus
 

B

backlog - Variable in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
Barista - Class in org.springframework.integration.samples.cafe
 
Barista() - Constructor for class org.springframework.integration.samples.cafe.Barista
 
barriers - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
BCC - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
bcc - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
beanClassLoader - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
beanClassLoader - Variable in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
BINARY_SOURCE_TYPE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
BinaryFileCopyDemo - Class in org.springframework.integration.samples.filecopy
Demonstrating the file copy scenario using binary file source and target.
BinaryFileCopyDemo() - Constructor for class org.springframework.integration.samples.filecopy.BinaryFileCopyDemo
 
BlockingSource<T> - Interface in org.springframework.integration.message
Extends PollableSource and provides a timeout-aware receive method.
BlockingTarget - Interface in org.springframework.integration.message
Extends Target and provides a timeout-aware send method.
BoundedHashMap<K,V> - Class in org.springframework.integration.util
A Map implementation that enforces the specified capacity.
BoundedHashMap(int) - Constructor for class org.springframework.integration.util.BoundedHashMap
 
ByteArrayFileMessageCreator - Class in org.springframework.integration.adapter.file
A MessageCreator implementation for messages with a byte array payload.
ByteArrayFileMessageCreator() - Constructor for class org.springframework.integration.adapter.file.ByteArrayFileMessageCreator
 
ByteArrayMailMessageMapper - Class in org.springframework.integration.adapter.mail
Message mapper used for mapping byte array messages to mail messages.
ByteArrayMailMessageMapper(JavaMailSender) - Constructor for class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
byteArrayMessageMapper - Variable in class org.springframework.integration.adapter.mail.MailTarget
 
bytesPerMessage - Variable in class org.springframework.integration.adapter.stream.ByteStreamSource
 
ByteStreamSource - Class in org.springframework.integration.adapter.stream
A pollable source for receiving bytes from an InputStream.
ByteStreamSource(InputStream) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamSource
 
ByteStreamSource(InputStream, int) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamSource
 
ByteStreamTarget - Class in org.springframework.integration.adapter.stream
A target that writes a byte array to an OutputStream.
ByteStreamTarget(OutputStream) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamTarget
 
ByteStreamTarget(OutputStream, int) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamTarget
 

C

Cafe - Class in org.springframework.integration.samples.cafe
The entry point for CafeDemo.
Cafe() - Constructor for class org.springframework.integration.samples.cafe.Cafe
 
CafeDemo - Class in org.springframework.integration.samples.cafe
Provides the 'main' method for running the Cafe Demo application.
CafeDemo() - Constructor for class org.springframework.integration.samples.cafe.CafeDemo
 
capacity - Variable in class org.springframework.integration.channel.factory.PriorityChannelFactory
 
capacity - Variable in class org.springframework.integration.util.BoundedHashMap
 
CC - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
cc - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
channel - Variable in class org.springframework.integration.bus.SubscriptionManager
 
channel - Variable in class org.springframework.integration.channel.ChannelPublisher
 
channel - Variable in class org.springframework.integration.scheduling.Subscription
 
CHANNEL_FACTORY_ATTRIBUTE - Static variable in class org.springframework.integration.config.MessageBusParser
 
channelAttributeName - Variable in class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
channelFactory - Variable in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
channelFactory - Variable in class org.springframework.integration.bus.MessageBus
 
ChannelFactory - Interface in org.springframework.integration.channel.factory
Interface for a channel factory.
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
 
channelMappings - Variable in class org.springframework.integration.router.PayloadTypeRouter
 
channelMappings - Variable in class org.springframework.integration.router.RootCauseErrorMessageRouter
 
channelName - Variable in class org.springframework.integration.scheduling.Subscription
 
channelNameAttribute - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
channelNameAttribute - Variable in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
ChannelNameResolver - Interface in org.springframework.integration.router
Strategy interface for content-based routing to a channel name.
channelNameResolver - Variable in class org.springframework.integration.router.MultiChannelRouter
 
channelNameResolver - Variable in class org.springframework.integration.router.SingleChannelRouter
 
channelNames - Variable in class org.springframework.integration.router.RecipientListRouter.RecipientListChannelNameResolver
 
ChannelPublisher - Class in org.springframework.integration.channel
Sends to a channel and provides a configurable timeout.
ChannelPublisher() - Constructor for class org.springframework.integration.channel.ChannelPublisher
 
ChannelPublisher(MessageChannel) - Constructor for class org.springframework.integration.channel.ChannelPublisher
 
ChannelPublishingJmsListener - Class in org.springframework.integration.adapter.jms
JMS MessageListener implementation that converts the received JMS message into a Spring Integration message and then sends that to a channel.
ChannelPublishingJmsListener(MessageChannel, MessageConverter) - Constructor for class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
ChannelPurger - Class in org.springframework.integration.channel
A utility class for purging Messages from one or more MessageChannels.
ChannelPurger(MessageChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
 
ChannelPurger(MessageSelector, MessageChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
 
channelRegistry - Variable in class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
channelRegistry - Variable in class org.springframework.integration.bus.MessageBus
 
ChannelRegistry - Interface in org.springframework.integration.channel
A strategy interface for registration and lookup of message channels by name.
channelRegistry - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
channelRegistry - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
channelRegistry - Variable in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
channelRegistry - Variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
channelRegistry - Variable in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
channelRegistry - Variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
ChannelRegistryAware - Interface in org.springframework.integration.channel
Interface to be implemented by components that need access to the ChannelRegistry.
ChannelResolver - Interface in org.springframework.integration.router
Strategy interface for content-based routing to a channel instance.
channelResolver - Variable in class org.springframework.integration.router.MultiChannelRouter
 
channelResolver - Variable in class org.springframework.integration.router.SingleChannelRouter
 
channels - Variable in class org.springframework.integration.channel.ChannelPurger
 
channels - Variable in class org.springframework.integration.channel.DefaultChannelRegistry
 
channels - Variable in class org.springframework.integration.router.RecipientListRouter.RecipientListChannelResolver
 
CharacterStreamSource - Class in org.springframework.integration.adapter.stream
A pollable source for Readers.
CharacterStreamSource(Reader) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamSource
 
CharacterStreamSource(Reader, int) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamSource
 
CharacterStreamTarget - Class in org.springframework.integration.adapter.stream
A target that writes to a Writer.
CharacterStreamTarget(Writer) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
CharacterStreamTarget(Writer, int) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
clear() - Method in interface org.springframework.integration.channel.MessageChannel
Remove all Messages from this channel.
clear() - Method in class org.springframework.integration.channel.QueueChannel
 
clear() - Method in class org.springframework.integration.channel.ThreadLocalChannel
Remove and return any messages that are stored for the current thread.
clear() - Method in class org.springframework.integration.dispatcher.DirectChannel
 
clear() - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
client - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
coldDrinkCounter - Variable in class org.springframework.integration.samples.cafe.Barista
 
coldDrinkDelay - Variable in class org.springframework.integration.samples.cafe.Barista
 
comparator - Variable in class org.springframework.integration.channel.factory.PriorityChannelFactory
 
compare(Message<?>, Message<?>) - Method in class org.springframework.integration.channel.PriorityChannel.MessagePriorityComparator
 
compare(Message<?>, Message<?>) - Method in class org.springframework.integration.router.MessageSequenceComparator
 
complete - Variable in class org.springframework.integration.router.AggregationBarrier
 
COMPLETION_STRATEGY_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
COMPLETION_STRATEGY_ELEMENT - Static variable in class org.springframework.integration.config.AggregatorParser
 
COMPLETION_STRATEGY_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
CompletionStrategy - 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.
completionStrategy - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
completionStrategy - Variable in class org.springframework.integration.router.AggregationBarrier
 
CompletionStrategy - Interface in org.springframework.integration.router
Strategy for determining when a group of messages reaches a state of completion (i.e.
CompletionStrategyAdapter - Class in org.springframework.integration.router
Adapter for methods annotated with @CompletionStrategy and for 'completion-strategy' elements that include a 'method' attribute (e.g.
CompletionStrategyAdapter(Object, Method) - Constructor for class org.springframework.integration.router.CompletionStrategyAdapter
 
CompletionStrategyAdapter(Object, String) - Constructor for class org.springframework.integration.router.CompletionStrategyAdapter
 
Concurrency - Annotation Type in org.springframework.integration.annotation
Defines the ConcurrencyPolicy settings for a @MessageEndpoint.
CONCURRENCY_ELEMENT - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
CONCURRENCY_POLICY_PROPERTY - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
ConcurrencyPolicy - Class in org.springframework.integration.endpoint
Metadata for configuring a pool of concurrent threads.
ConcurrencyPolicy() - Constructor for class org.springframework.integration.endpoint.ConcurrencyPolicy
 
ConcurrencyPolicy(int, int) - Constructor for class org.springframework.integration.endpoint.ConcurrencyPolicy
 
concurrencyPolicy - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
concurrentConsumers - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
ConcurrentTarget - Class in org.springframework.integration.endpoint
A Target implementation that encapsulates an Executor and delegates to a wrapped target for concurrent, asynchronous message handling.
ConcurrentTarget(Target, ExecutorService) - Constructor for class org.springframework.integration.endpoint.ConcurrentTarget
 
ConcurrentTarget.TargetTask - Class in org.springframework.integration.endpoint
 
ConcurrentTarget.TargetTask(Message<?>) - Constructor for class org.springframework.integration.endpoint.ConcurrentTarget.TargetTask
 
ConfigurationException - Exception in org.springframework.integration
Exception that indicates an incorrectly configured integration component.
ConfigurationException(String) - Constructor for exception org.springframework.integration.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.springframework.integration.ConfigurationException
 
configureAsyncEventMulticaster - Variable in class org.springframework.integration.bus.MessageBus
 
configureCompletionStrategy(Object, HandlerEndpoint) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.PriorityChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.QueueChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.RendezvousChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.ThreadLocalChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.config.DefaultChannelParser
 
configureConstructorArgs(BeanDefinitionBuilder, Element, DispatcherPolicy) - Method in class org.springframework.integration.config.DirectChannelParser
 
configureDispatcherPolicy(Element, DispatcherPolicy) - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
configureInput(Object, String, MessageEndpoint, Polled, HandlerEndpoint) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
configureOutput(Object, String, HandlerEndpoint) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
CONNECTION_FACTORY_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
CONNECTION_FACTORY_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
connectionFactory - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
connectionFactory - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
ConsoleSourceParser - Class in org.springframework.integration.adapter.stream.config
Parser for the <console-source> element.
ConsoleSourceParser() - Constructor for class org.springframework.integration.adapter.stream.config.ConsoleSourceParser
 
ConsoleTargetParser - Class in org.springframework.integration.adapter.stream.config
Parser for the <console-target> element.
ConsoleTargetParser() - Constructor for class org.springframework.integration.adapter.stream.config.ConsoleTargetParser
 
container - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
converter - Variable in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
converter - Variable in class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
convertMessageToMailMessage(Message<?>) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
copyHeader(MessageHeader, boolean) - Method in class org.springframework.integration.message.GenericMessage
 
copyHeader(MessageHeader, boolean) - Method in interface org.springframework.integration.message.Message
 
CORE_SIZE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
coreSize - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
CORRELATION_ID - Static variable in class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
correlationId - Variable in class org.springframework.integration.message.MessageHeader
 
count - Variable in class org.springframework.integration.samples.oddeven.Counter
 
Counter - Class in org.springframework.integration.samples.oddeven
 
Counter() - Constructor for class org.springframework.integration.samples.oddeven.Counter
 
createAdapterAndReturnBeanName(ParserContext, String, String, Class<?>) - Method in class org.springframework.integration.config.AggregatorParser
 
createAdvisor() - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.channel.factory.AbstractChannelFactory
Factory method to be overridden by subclasses.
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.channel.factory.PriorityChannelFactory
 
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.channel.factory.QueueChannelFactory
 
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.channel.factory.RendezvousChannelFactory
 
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.channel.factory.ThreadLocalChannelFactory
 
createChannelInternal(DispatcherPolicy) - Method in class org.springframework.integration.dispatcher.DirectChannelFactory
 
createDefaultContainer() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
createDefaultJmsTemplate() - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
createHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.handler.config.AbstractMessageHandlerCreator
 
createHandler(Object, Method, Map<String, ?>) - Method in interface org.springframework.integration.handler.config.MessageHandlerCreator
 
createHandlerChain(Object, String) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
createHandlerProxy(String) - Method in class org.springframework.integration.adapter.AbstractRemotingTargetAdapter
Subclasses must implement this method.
createHandlerProxy(String) - Method in class org.springframework.integration.adapter.httpinvoker.HttpInvokerTargetAdapter
 
createHandlerProxy(String) - Method in class org.springframework.integration.adapter.rmi.RmiTargetAdapter
 
createMessage(MessagingEvent<T>) - Method in class org.springframework.integration.adapter.event.MessagingEventMapper
 
createMessage(File) - Method in class org.springframework.integration.adapter.file.AbstractFileMessageCreator
 
createMessage(Object) - Method in class org.springframework.integration.message.DefaultMessageCreator
 
createMessage(O) - Method in interface org.springframework.integration.message.MessageCreator
 
createMessageEndpointPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
createPublisherPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
createReplyMessage(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
createSubscriberPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
createTargetForStream(OutputStream, String) - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 

D

DATATYPE_ATTRIBUTE - Static variable in class org.springframework.integration.channel.config.AbstractChannelParser
 
DEFAULT_CAPACITY - Static variable in class org.springframework.integration.channel.QueueChannel
 
DEFAULT_CONCURRENCY_ELEMENT - Static variable in class org.springframework.integration.config.MessageBusParser
 
DEFAULT_CONCURRENCY_PROPERTY - Static variable in class org.springframework.integration.config.MessageBusParser
 
DEFAULT_CORE_SIZE - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_DISPATCHER_POOL_SIZE - Static variable in class org.springframework.integration.bus.MessageBus
 
DEFAULT_FIXED_RATE - Static variable in class org.springframework.integration.scheduling.PollingSchedule
 
DEFAULT_HOST - Static variable in class org.springframework.integration.adapter.ftp.FtpSource
 
DEFAULT_INITIAL_DELAY - Static variable in class org.springframework.integration.scheduling.PollingSchedule
 
DEFAULT_KEEP_ALIVE_SECONDS - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_MAX_MESSAGES_PER_TASK - Static variable in class org.springframework.integration.channel.DispatcherPolicy
 
DEFAULT_MAX_SIZE - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_PORT - Static variable in class org.springframework.integration.adapter.ftp.FtpSource
 
DEFAULT_QUEUE_CAPACITY - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_REAPER_INTERVAL - Static variable in class org.springframework.integration.router.AggregatingMessageHandler
 
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.channel.DispatcherPolicy
 
DEFAULT_REJECTION_LIMIT - Static variable in class org.springframework.integration.channel.DispatcherPolicy
 
DEFAULT_REMOTE_WORKING_DIRECTORY - Static variable in class org.springframework.integration.adapter.ftp.FtpSource
 
DEFAULT_REPLY_CHANNEL - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
DEFAULT_REPLY_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
DEFAULT_REPLY_CHANNEL_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.channel.DispatcherPolicy
 
DEFAULT_SEND_TIMEOUT - Static variable in class org.springframework.integration.router.AggregatingMessageHandler
 
DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.router.AggregatingMessageHandler
 
DEFAULT_TRACKED_CORRRELATION_ID_CAPACITY - Static variable in class org.springframework.integration.router.AggregatingMessageHandler
 
defaultChannel - Variable in class org.springframework.integration.aop.MessagePublishingInterceptor
 
defaultChannel - Variable in class org.springframework.integration.router.PayloadTypeRouter
 
defaultChannel - Variable in class org.springframework.integration.router.RootCauseErrorMessageRouter
 
DefaultChannelFactoryBean - Class in org.springframework.integration.bus
Creates a channel by delegating to the current message bus' configured ChannelFactory.
DefaultChannelFactoryBean(DispatcherPolicy) - Constructor for class org.springframework.integration.bus.DefaultChannelFactoryBean
 
DefaultChannelParser - Class in org.springframework.integration.config
Parser for the <channel> element.
DefaultChannelParser() - Constructor for class org.springframework.integration.config.DefaultChannelParser
 
DefaultChannelRegistry - Class in org.springframework.integration.channel
A simple map-backed implementation of ChannelRegistry.
DefaultChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultChannelRegistry
 
defaultConcurrencyPolicy - Variable in class org.springframework.integration.bus.MessageBus
 
defaultDispatcherPolicy() - Static method in class org.springframework.integration.channel.ThreadLocalChannel
 
defaultDispatcherPolicy() - Static method in class org.springframework.integration.dispatcher.DirectChannel
 
DefaultEndpointRegistry - Class in org.springframework.integration.endpoint
A simple map-backed implementation of EndpointRegistry.
DefaultEndpointRegistry() - Constructor for class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
DefaultErrorChannel - Class in org.springframework.integration.bus
The default error channel implementation used by the MessageBus.
DefaultErrorChannel() - Constructor for class org.springframework.integration.bus.DefaultErrorChannel
 
DefaultErrorChannel.ErrorLoggingInterceptor - Class in org.springframework.integration.bus
 
DefaultErrorChannel.ErrorLoggingInterceptor() - Constructor for class org.springframework.integration.bus.DefaultErrorChannel.ErrorLoggingInterceptor
 
DefaultFileNameGenerator - Class in org.springframework.integration.adapter.file
Default implementation of the filename generator strategy.
DefaultFileNameGenerator() - Constructor for class org.springframework.integration.adapter.file.DefaultFileNameGenerator
 
defaultIdGenerator - Variable in class org.springframework.integration.message.GenericMessage
 
DefaultJmsHeaderMapper - Class in org.springframework.integration.adapter.jms
A HeaderMapper implementation for JMS Messages.
DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.adapter.jms.DefaultJmsHeaderMapper
 
DefaultMailHeaderGenerator - Class in org.springframework.integration.adapter.mail
The default implementation of MailHeaderGenerator.
DefaultMailHeaderGenerator() - Constructor for class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
DefaultMessageCreator - Class in org.springframework.integration.message
A simple implementation of MessageCreator that uses the provide value as the Message's payload.
DefaultMessageCreator() - Constructor for class org.springframework.integration.message.DefaultMessageCreator
 
DefaultMessageHandlerAdapter - Class in org.springframework.integration.handler
An implementation of MessageHandler that invokes the specified method and target object.
DefaultMessageHandlerAdapter() - Constructor for class org.springframework.integration.handler.DefaultMessageHandlerAdapter
 
DefaultMessageHandlerCreator - Class in org.springframework.integration.handler.config
Default implementation of the handler creator strategy that creates a DefaultMessageHandlerAdapter for the provided object and method.
DefaultMessageHandlerCreator() - Constructor for class org.springframework.integration.handler.config.DefaultMessageHandlerCreator
 
DefaultMessageMapper - Class in org.springframework.integration.message
A simple implementation of MessageMapper that returns the Message's payload.
DefaultMessageMapper() - Constructor for class org.springframework.integration.message.DefaultMessageMapper
 
DefaultMethodInvoker - Class in org.springframework.integration.util
Implementation of MethodInvoker to be used when the actual Method reference is known.
DefaultMethodInvoker(Object, Method) - Constructor for class org.springframework.integration.util.DefaultMethodInvoker
 
DefaultOutput - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of sending messages.
DefaultPollingDispatcher - Class in org.springframework.integration.dispatcher
A subclass of SimpleDispatcher that adds message retrieval capabilities by polling a PollableSource for Messages.
DefaultPollingDispatcher(MessageChannel) - Constructor for class org.springframework.integration.dispatcher.DefaultPollingDispatcher
 
DefaultPollingDispatcher(Source<?>, DispatcherPolicy) - Constructor for class org.springframework.integration.dispatcher.DefaultPollingDispatcher
 
defaultReplyChannel - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
defaultSchedule - Variable in class org.springframework.integration.bus.SubscriptionManager
 
defaultTimeout - Variable in class org.springframework.integration.handler.ReplyMessageCorrelator
 
destination - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
destination - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
DESTINATION_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
DESTINATION_NAME_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
DESTINATION_NAME_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
DESTINATION_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
destinationName - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
destinationName - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
destroy() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
destroy() - Method in class org.springframework.integration.endpoint.ConcurrentTarget
 
determineConnectionFactoryBeanName(Element) - Static method in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
DirectChannel - Class in org.springframework.integration.dispatcher
A channel that invokes the subscribed handler(s) in a sender's thread (returning after at most one handles the message).
DirectChannel() - Constructor for class org.springframework.integration.dispatcher.DirectChannel
 
DirectChannel(Source<?>) - Constructor for class org.springframework.integration.dispatcher.DirectChannel
 
DirectChannelFactory - Class in org.springframework.integration.dispatcher
A ChannelFactory for creating DirectChannel instances.
DirectChannelFactory() - Constructor for class org.springframework.integration.dispatcher.DirectChannelFactory
 
DirectChannelParser - Class in org.springframework.integration.config
Parser for the <direct-channel> element.
DirectChannelParser() - Constructor for class org.springframework.integration.config.DirectChannelParser
 
directory - Variable in class org.springframework.integration.adapter.file.FileSource
 
DIRECTORY_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
DIRECTORY_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileTargetParser
 
directoryContentManager - Variable in class org.springframework.integration.adapter.file.FileSource
 
DirectoryContentManager - Class in org.springframework.integration.adapter.ftp
Tracks changes in a directory.
DirectoryContentManager() - Constructor for class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
directoryContentManager - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
DISCARD_CHANNEL - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
DISCARD_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
DISCARD_CHANNEL_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
discardChannel - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.DefaultPollingDispatcher
 
dispatch(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.SimpleDispatcher
 
dispatchAdviceChain - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
dispatcher - Variable in class org.springframework.integration.dispatcher.DirectChannel
 
dispatcher - Variable in class org.springframework.integration.dispatcher.PollingDispatcherTask
 
dispatcher - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
DISPATCHER_POLICY_ELEMENT - Static variable in class org.springframework.integration.channel.config.AbstractChannelParser
 
dispatcherPolicy - Variable in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
dispatcherPolicy - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
DispatcherPolicy - Class in org.springframework.integration.channel
Metadata for a MessageDispatcher.
DispatcherPolicy() - Constructor for class org.springframework.integration.channel.DispatcherPolicy
 
DispatcherPolicy(boolean) - Constructor for class org.springframework.integration.channel.DispatcherPolicy
Create a DispatcherPolicy.
dispatcherPolicy - Variable in class org.springframework.integration.dispatcher.SimpleDispatcher
 
dispatcherPolicy - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
dispatcherTasks - Variable in class org.springframework.integration.bus.SubscriptionManager
 
doConfigureAsyncEventMulticaster(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.handler.config.AbstractMessageHandlerCreator
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.handler.config.DefaultMessageHandlerCreator
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.router.config.RouterMessageHandlerCreator
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.router.config.SplitterMessageHandlerCreator
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.adapter.MarshallingWebServiceTargetAdapter
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.file.config.FileTargetParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerTargetAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.jms.config.JmsGatewayParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.jms.config.JmsTargetParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.mail.config.MailTargetParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.rmi.config.RmiTargetAdapterParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.stream.config.ConsoleSourceParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.stream.config.ConsoleTargetParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.MessageBusParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.MethodInvokingAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.SourceEndpointParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.router.config.RouterParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.router.config.SplitterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
Subclasses may add to the bean definition by overriding this method.
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.adapter.rmi.config.RmiSourceAdapterParser
 
doReceive(long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
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(long) - Method in class org.springframework.integration.channel.ThreadLocalChannel
 
doReceive(long) - Method in class org.springframework.integration.dispatcher.DirectChannel
 
doRegisterEndpoint(String, TargetEndpoint, Subscription, ConcurrencyPolicy) - Method in class org.springframework.integration.bus.MessageBus
 
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.PriorityChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.QueueChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.ThreadLocalChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.dispatcher.DirectChannel
 
doWithMessage(WebServiceMessage) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter.TypeCheckingSoapActionCallback
 
Drink - Class in org.springframework.integration.samples.cafe
 
Drink(DrinkType, int, boolean) - Constructor for class org.springframework.integration.samples.cafe.Drink
 
DrinkOrder - Class in org.springframework.integration.samples.cafe
 
DrinkOrder() - Constructor for class org.springframework.integration.samples.cafe.DrinkOrder
 
DrinkRouter - Class in org.springframework.integration.samples.cafe
 
DrinkRouter() - Constructor for class org.springframework.integration.samples.cafe.DrinkRouter
 
drinks - Variable in class org.springframework.integration.samples.cafe.DrinkOrder
 
DrinkType - Enum in org.springframework.integration.samples.cafe
 
DrinkType() - Constructor for enum org.springframework.integration.samples.cafe.DrinkType
 

E

EndpointPolicy - Interface in org.springframework.integration.endpoint
A marker interface for endpoint metadata.
endpointRegistry - Variable in class org.springframework.integration.bus.MessageBus
 
EndpointRegistry - Interface in org.springframework.integration.endpoint
A strategy interface for registration and lookup of message endpoints by name.
endpointRegistry - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
endpoints - Variable in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
equals(Object) - Method in class org.springframework.integration.adapter.ftp.FileInfo
 
equals(Object) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
ERROR_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.MessageBusParser
 
ERROR_CHANNEL_NAME - Static variable in class org.springframework.integration.bus.MessageBus
 
ERROR_HANDLER_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
ERROR_HANDLER_PROPERTY - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
errorChannel - Variable in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
errorHandler - Variable in class org.springframework.integration.endpoint.ConcurrentTarget
 
errorHandler - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
errorHandler - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
ErrorHandler - Interface in org.springframework.integration.util
Strategy for handling a Throwable.
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(Object, Throwable) - Constructor for class org.springframework.integration.message.ErrorMessage
 
establishConnection() - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
even(int) - Method in class org.springframework.integration.samples.oddeven.NumberLogger
 
eventTypes - Variable in class org.springframework.integration.adapter.event.ApplicationEventSource
 
exclaim(String) - Method in class org.springframework.integration.samples.filecopy.Exclaimer
 
exclaim(File) - Method in class org.springframework.integration.samples.filecopy.Exclaimer
 
exclaim(byte[]) - Method in class org.springframework.integration.samples.filecopy.Exclaimer
 
Exclaimer - Class in org.springframework.integration.samples.filecopy
A class providing several handling methods for different types of payloads.
Exclaimer() - Constructor for class org.springframework.integration.samples.filecopy.Exclaimer
 
execute(Runnable) - Method in class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
Submit a task to be run once.
executeMethod(List<Message<?>>) - Method in class org.springframework.integration.router.MessageListMethodAdapter
 
executor - Variable in class org.springframework.integration.bus.MessageBus
 
executor - Variable in class org.springframework.integration.endpoint.ConcurrentTarget
 
executor - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
executor - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
expectReply - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
expectReply - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
expiration - Variable in class org.springframework.integration.message.MessageHeader
 
exporter - Variable in class org.springframework.integration.adapter.httpinvoker.HttpInvokerSourceAdapter
 
extractData(Source) - Method in class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter.DefaultSourceExtractor
 
extractPayloadsFromMessages(List<Message<?>>) - Method in class org.springframework.integration.router.MessageListMethodAdapter
 

F

failedMessage - Variable in exception org.springframework.integration.message.MessagingException
 
FILE_NAME_GENERATOR_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileTargetParser
 
FILE_SOURCE_TYPE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
FileBasedFileCopyDemo - Class in org.springframework.integration.samples.filecopy
Demonstrating the file copy scenario using file-based source and target.
FileBasedFileCopyDemo() - Constructor for class org.springframework.integration.samples.filecopy.FileBasedFileCopyDemo
 
FileCopyDemoCommon - Class in org.springframework.integration.samples.filecopy
Common functionality for the file demo.
FileCopyDemoCommon() - Constructor for class org.springframework.integration.samples.filecopy.FileCopyDemoCommon
 
fileFilter - Variable in class org.springframework.integration.adapter.file.FileSource
 
FileInfo - Class in org.springframework.integration.adapter.ftp
Information about a file in a directory.
FileInfo(String, long, long) - Constructor for class org.springframework.integration.adapter.ftp.FileInfo
 
FileMessageCreator - Class in org.springframework.integration.adapter.file
A MessageCreator that creates Message instances with the absolute path to the File as payload.
FileMessageCreator() - Constructor for class org.springframework.integration.adapter.file.FileMessageCreator
 
fileName - Variable in class org.springframework.integration.adapter.ftp.FileInfo
 
FILENAME_PROPERTY_KEY - Static variable in interface org.springframework.integration.adapter.file.FileNameGenerator
 
filenameFilter - Variable in class org.springframework.integration.adapter.file.FileSource
 
FileNameGenerator - Interface in org.springframework.integration.adapter.file
Strategy interface for generating a file name from a message.
fileNameGenerator - Variable in class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
fileProcessed(String) - Method in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
FileSource - Class in org.springframework.integration.adapter.file
A messaging source that polls a directory to retrieve files.
FileSource(File) - Constructor for class org.springframework.integration.adapter.file.FileSource
 
FileSource(File, MessageCreator<File, ?>) - Constructor for class org.springframework.integration.adapter.file.FileSource
 
FileSourceParser - Class in org.springframework.integration.adapter.file.config
Parser for the <file-source/> element.
FileSourceParser() - Constructor for class org.springframework.integration.adapter.file.config.FileSourceParser
 
FileTarget - Class in org.springframework.integration.adapter.file
A message target for writing files.
FileTarget(MessageMapper<?, File>) - Constructor for class org.springframework.integration.adapter.file.FileTarget
 
FileTargetParser - Class in org.springframework.integration.adapter.file.config
Parser for the <file-target/> element.
FileTargetParser() - Constructor for class org.springframework.integration.adapter.file.config.FileTargetParser
 
fixedRate - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
FROM - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
from - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
fromMessage(Message) - Method in class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
FtpSource - Class in org.springframework.integration.adapter.ftp
A source adapter for receiving files via FTP.
FtpSource() - Constructor for class org.springframework.integration.adapter.ftp.FtpSource
 
FtpSourceParser - Class in org.springframework.integration.adapter.ftp.config
Parser for the <ftp-source/> element.
FtpSourceParser() - Constructor for class org.springframework.integration.adapter.ftp.config.FtpSourceParser
 

G

GatewayParser - Class in org.springframework.integration.gateway.config
Parser for the <gateway/> element.
GatewayParser() - Constructor for class org.springframework.integration.gateway.config.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.
GatewayProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
generateFileName(Message<?>) - Method in class org.springframework.integration.adapter.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.adapter.file.FileNameGenerator
 
generateId() - Method in interface org.springframework.integration.util.IdGenerator
Generate a new unique id.
generateId() - Method in class org.springframework.integration.util.RandomUuidGenerator
 
generateTicker() - Method in class org.springframework.integration.samples.quote.QuotePublisher
 
GenericMessage<T> - Class in org.springframework.integration.message
Base Message class defining common properties such as id, header, and lock.
GenericMessage(Object, T) - Constructor for class org.springframework.integration.message.GenericMessage
Create a new message with the given id and payload.
GenericMessage(T) - Constructor for class org.springframework.integration.message.GenericMessage
Create a new message with the given payload.
GenericMessage(T, MessageHeader) - Constructor for class org.springframework.integration.message.GenericMessage
Create a new message with the given payload.
get(Object) - Method in interface org.springframework.integration.message.MessageStore
 
get(Object) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
get(Object, long) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
get(Object) - Method in class org.springframework.integration.message.SimpleMessageStore
 
getAdapterClass() - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
getAdapterClass() - Method in class org.springframework.integration.config.HandlerEndpointParser
 
getAdapterClass() - Method in class org.springframework.integration.config.TargetEndpointParser
 
getAdvice() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getAttribute(String) - Method in class org.springframework.integration.message.MessageHeader
 
getAttributeNames() - Method in class org.springframework.integration.message.MessageHeader
 
getBacklog() - Method in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
getBcc(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the BCC recipients list from an integration message.
getBcc(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getBcc(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.file.config.FileSourceParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.file.config.FileTargetParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.ftp.config.FtpSourceParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerSourceAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerTargetAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.jms.config.JmsGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.jms.config.JmsTargetParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.mail.config.MailTargetParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.rmi.config.RmiSourceAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.rmi.config.RmiTargetAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.stream.config.ConsoleSourceParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.stream.config.ConsoleTargetParser
 
getBeanClass(Element) - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.channel.config.PriorityChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.channel.config.QueueChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.channel.config.RendezvousChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.channel.config.ThreadLocalChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.DefaultChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.DirectChannelParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.HandlerEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.MessageBusParser
 
getBeanClass(Object) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
getBeanClass(Element) - Method in class org.springframework.integration.config.MethodInvokingAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.SourceEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.TargetEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.gateway.config.GatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.router.config.RouterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.router.config.SplitterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
getCc(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the CC recipients list from an integration message.
getCc(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getCc(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getChannel() - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
getChannel() - Method in class org.springframework.integration.channel.ChannelPublisher
 
getChannel(DispatcherPolicy, List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.factory.AbstractChannelFactory
 
getChannel(DispatcherPolicy, List<ChannelInterceptor>) - Method in interface org.springframework.integration.channel.factory.ChannelFactory
Creates a channel, based on the provided dispatcher policy, and with the given interceptors.
getChannel() - Method in class org.springframework.integration.scheduling.Subscription
 
getChannelFactory() - Method in class org.springframework.integration.bus.MessageBus
 
getChannelName() - Method in class org.springframework.integration.scheduling.Subscription
 
getChannelRegistry() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
getChannelRegistry() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
getCollectionActualType(Method) - Static method in class org.springframework.integration.router.MessageListMethodAdapter
 
getConcurrencyPolicy() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
getCoreSize() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getCorrelationId(Message<?>) - Method in class org.springframework.integration.handler.ReplyMessageCorrelator
Retrieve the correlation identifier from the provided message.
getCorrelationId() - Method in class org.springframework.integration.message.MessageHeader
 
getDispatcher() - Method in class org.springframework.integration.dispatcher.PollingDispatcherTask
 
getDispatcherPolicy() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return the dispatcher policy for this channel.
getDispatcherPolicy() - Method in interface org.springframework.integration.channel.MessageChannel
Return this channel's dispatcher policy
getDispatcherPolicy() - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
getDrinks() - Method in class org.springframework.integration.samples.cafe.DrinkOrder
 
getEndpointNames() - Method in class org.springframework.integration.bus.MessageBus
 
getEndpointNames() - Method in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
getEndpointNames() - Method in interface org.springframework.integration.endpoint.EndpointRegistry
 
getErrorChannel() - Method in class org.springframework.integration.bus.MessageBus
 
getExpiration() - Method in class org.springframework.integration.message.MessageHeader
Return the expiration date for this message or null to indicate 'never expire'.
getFailedMessage() - Method in exception org.springframework.integration.message.MessagingException
 
getFileName() - Method in class org.springframework.integration.adapter.ftp.FileInfo
 
getFixedRate() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getFrom(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the From: e-mail address from an integration message.
getFrom(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getFrom(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getHandler() - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
getHandlers() - Method in class org.springframework.integration.handler.MessageHandlerChain
Get an immutable list of handlers
getHeader() - Method in class org.springframework.integration.message.GenericMessage
 
getHeader() - Method in interface org.springframework.integration.message.Message
 
getHeaderAttributes(Message<?>) - Method in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
getHeaderProperties(Message<?>) - Method in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
getId() - Method in class org.springframework.integration.message.GenericMessage
 
getId() - Method in interface org.springframework.integration.message.Message
 
getInitialDelay() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getJmsTemplate() - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
getKeepAliveSeconds() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getMaxMessagesPerTask() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return the maximum number of messages for each retrieval attempt.
getMaxSize() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getMessage() - Method in class org.springframework.integration.adapter.event.MessagingEvent
 
getMessage() - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore.MessageHolder
 
getMessages() - Method in class org.springframework.integration.router.AggregationBarrier
 
getMethod() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
getMethod() - Method in class org.springframework.integration.router.MessageListMethodAdapter
 
getModificationTimestamp() - Method in class org.springframework.integration.adapter.ftp.FileInfo
 
getName() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return the name of this channel.
getName() - Method in interface org.springframework.integration.channel.MessageChannel
Return the name of this channel.
getName() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
getName() - Method in interface org.springframework.integration.endpoint.MessageEndpoint
 
getName() - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
getNumber() - Method in class org.springframework.integration.samples.oddeven.Counter
 
getObject() - Method in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
getObjectType() - Method in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
getOutputChannelName() - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
getPayload() - Method in class org.springframework.integration.message.GenericMessage
 
getPayload() - Method in interface org.springframework.integration.message.Message
 
getPeriod() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getPriority() - Method in class org.springframework.integration.message.MessageHeader
 
getProperty(String) - Method in class org.springframework.integration.message.MessageHeader
 
getPropertyNames() - Method in class org.springframework.integration.message.MessageHeader
 
getQueueCapacity() - Method in class org.springframework.integration.channel.factory.QueueChannelFactory
 
getQueueCapacity() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getQuote(String) - Method in class org.springframework.integration.samples.quote.QuotePublisher
 
getReceiveTimeout() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return the maximum amount of time in milliseconds to wait for a message to be available.
getRejectionLimit() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return the maximum number of retries upon rejection.
getReply(Object) - Method in class org.springframework.integration.handler.ReplyMessageCorrelator
 
getReply(Object, long) - Method in class org.springframework.integration.handler.ReplyMessageCorrelator
 
getReplyTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the Reply To: e-mail address from an integration message.
getReplyTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getReplyTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getRequestCallback(Message<?>) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
getRequestReplyTemplate() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getRetryInterval() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return the amount of time in milliseconds to wait between rejections.
getReturnAddress(MessageHeader) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
getReturnAddress() - Method in class org.springframework.integration.message.MessageHeader
 
getSchedule() - Method in class org.springframework.integration.dispatcher.PollingDispatcherTask
 
getSchedule() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
getSchedule() - Method in interface org.springframework.integration.scheduling.MessagingTask
 
getSchedule() - Method in class org.springframework.integration.scheduling.Subscription
 
getScheduleElement(Element) - Method in class org.springframework.integration.config.SourceEndpointParser
 
getSequenceNumber() - Method in class org.springframework.integration.message.MessageHeader
 
getSequenceSize() - Method in class org.springframework.integration.message.MessageHeader
 
getShouldFailOnRejectionLimit() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return whether an exception should be thrown when this dispatcher's DispatcherPolicy.rejectionLimit is reached.
getSize() - Method in class org.springframework.integration.adapter.ftp.FileInfo
 
getSubject(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the subject of an e-mail message from an integration message.
getSubject(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getSubject(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getSubscription() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
getTarget() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
getTargetAttributeName() - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
getTargetAttributeName() - Method in class org.springframework.integration.config.HandlerEndpointParser
 
getTargetAttributeName() - Method in class org.springframework.integration.config.TargetEndpointParser
 
getTask() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
getTimestamp() - Method in class org.springframework.integration.message.MessageHeader
Return the creation time of this message.
getTimestamp() - Method in class org.springframework.integration.router.AggregationBarrier
Returns the creation time of this barrier as the number of milliseconds since January 1, 1970.
getTimeUnit() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Retrieve the recipients list from an integration message.
getTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
getTo(Message<?>) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
getTypeConverter() - Method in class org.springframework.integration.util.DefaultMethodInvoker
 
getWebServiceTemplate() - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 

H

handle(Message<?>) - Method in class org.springframework.integration.adapter.AbstractRemotingTargetAdapter
 
handle(Message<?>) - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
handle(Message<?>, MessageHeader) - Method in class org.springframework.integration.endpoint.HandlerEndpoint.EndpointReplyHandler
 
handle(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
handle(Message<?>) - Method in class org.springframework.integration.handler.InterceptingMessageHandler
 
handle(Message<?>, MessageHandler) - Method in class org.springframework.integration.handler.InterceptingMessageHandler
The handler method for subclasses to implement.
handle(Message<?>) - Method in interface org.springframework.integration.handler.MessageHandler
 
handle(Message<?>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
handle(Message<?>, MessageHeader) - Method in interface org.springframework.integration.handler.ReplyHandler
 
handle(Message<?>) - Method in class org.springframework.integration.handler.ReplyMessageCorrelator
 
handle(Message<?>) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
handle(Message<?>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
handle(Throwable) - Method in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
handle(Message<?>) - Method in class org.springframework.integration.transformer.MessageFilter
 
handle(Throwable) - Method in interface org.springframework.integration.util.ErrorHandler
 
handle(Message<?>) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
Handler - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of handling a message or message payload.
handler - Variable in class org.springframework.integration.endpoint.HandlerEndpoint
 
handler - Variable in class org.springframework.integration.endpoint.HandlerEndpoint.HandlerInvokingTarget
 
HANDLER_CHAIN_ELEMENT - Static variable in class org.springframework.integration.config.HandlerParser
 
HANDLER_ELEMENT - Static variable in class org.springframework.integration.config.HandlerParser
 
handlerCount - Variable in class org.springframework.integration.dispatcher.DirectChannel
 
handlerCreators - Variable in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
HandlerEndpoint - Class in org.springframework.integration.endpoint
Implementation of the MessageEndpoint interface for invoking MessageHandlers.
HandlerEndpoint(MessageHandler) - Constructor for class org.springframework.integration.endpoint.HandlerEndpoint
 
HandlerEndpoint.EndpointReplyHandler - Class in org.springframework.integration.endpoint
 
HandlerEndpoint.EndpointReplyHandler() - Constructor for class org.springframework.integration.endpoint.HandlerEndpoint.EndpointReplyHandler
 
HandlerEndpoint.HandlerInvokingTarget - Class in org.springframework.integration.endpoint
 
HandlerEndpoint.HandlerInvokingTarget(MessageHandler, ReplyHandler) - Constructor for class org.springframework.integration.endpoint.HandlerEndpoint.HandlerInvokingTarget
 
HandlerEndpointParser - Class in org.springframework.integration.config
Parser for the handler-endpoint element of the integration namespace.
HandlerEndpointParser() - Constructor for class org.springframework.integration.config.HandlerEndpointParser
 
handleRequest(HttpServletRequest, HttpServletResponse) - Method in class org.springframework.integration.adapter.httpinvoker.HttpInvokerSourceAdapter
 
handleReturnValue(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
Subclasses must implement this method to handle the return value.
handleReturnValue(Object, Message<?>) - Method in class org.springframework.integration.handler.DefaultMessageHandlerAdapter
 
handleReturnValue(Object, Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingTarget
 
handleReturnValue(Object, Message<?>) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
handleReturnValue(Object, Message<?>) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
HandlerParser - Class in org.springframework.integration.config
Parser for the <handler/> element.
HandlerParser() - Constructor for class org.springframework.integration.config.HandlerParser
 
handlerProxy - Variable in class org.springframework.integration.adapter.AbstractRemotingTargetAdapter
 
handlers - Variable in class org.springframework.integration.handler.MessageHandlerChain
 
HANDLERS_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
hasErrorHandler() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
hashCode() - Method in class org.springframework.integration.adapter.ftp.FileInfo
 
hashCode() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
header - Variable in class org.springframework.integration.message.GenericMessage
 
HEADER_MAPPER_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
HEADER_MAPPER_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
HeaderAttribute - Annotation Type in org.springframework.integration.handler.annotation
Annotation indicating that a method parameter's value should be retrieved from an attribute in the message header.
headerMapper - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
headerMapper - Variable in class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
HeaderMappingMessageConverter - Class in org.springframework.integration.adapter.jms
A MessageConverter implementation that delegates to an existing converter as well as an implementation of MessageHeaderMapper.
HeaderMappingMessageConverter(MessageConverter) - Constructor for class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
HeaderMappingMessageConverter(MessageConverter, MessageHeaderMapper<Message>) - Constructor for class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
HeaderProperty - Annotation Type in org.springframework.integration.handler.annotation
Annotation indicating that a method parameter's value should be retrieved from a property in the message header.
HelloService - Class in org.springframework.integration.samples.helloworld
 
HelloService() - Constructor for class org.springframework.integration.samples.helloworld.HelloService
 
HelloWorldDemo - Class in org.springframework.integration.samples.helloworld
Demonstrates a basic message endpoint.
HelloWorldDemo() - Constructor for class org.springframework.integration.samples.helloworld.HelloWorldDemo
 
host - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
hotDrinkCounter - Variable in class org.springframework.integration.samples.cafe.Barista
 
hotDrinkDelay - Variable in class org.springframework.integration.samples.cafe.Barista
 
HttpInvokerSourceAdapter - Class in org.springframework.integration.adapter.httpinvoker
A source channel adapter for HttpInvoker-based remoting.
HttpInvokerSourceAdapter(MessageChannel) - Constructor for class org.springframework.integration.adapter.httpinvoker.HttpInvokerSourceAdapter
 
HttpInvokerSourceAdapterParser - Class in org.springframework.integration.adapter.httpinvoker.config
Parser for the <httpinvoker-source/> element.
HttpInvokerSourceAdapterParser() - Constructor for class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerSourceAdapterParser
 
HttpInvokerTargetAdapter - Class in org.springframework.integration.adapter.httpinvoker
A target channel adapter for HttpInvoker-based remoting.
HttpInvokerTargetAdapter(String) - Constructor for class org.springframework.integration.adapter.httpinvoker.HttpInvokerTargetAdapter
 
HttpInvokerTargetAdapterParser - Class in org.springframework.integration.adapter.httpinvoker.config
Parser for the <httpinvoker-target/> element.
HttpInvokerTargetAdapterParser() - Constructor for class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerTargetAdapterParser
 

I

iced - Variable in class org.springframework.integration.samples.cafe.Drink
 
id - Variable in class org.springframework.integration.message.GenericMessage
 
ID_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
IdGenerator - Interface in org.springframework.integration.util
A strategy for generating unique ids.
idleTaskExecutionLimit - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
init() - Method in class org.springframework.integration.config.IntegrationNamespaceHandler
 
initialDelay - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
initializationMonitor - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
initializationMonitor - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
initializationMonitor - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
initialize() - Method in class org.springframework.integration.adapter.httpinvoker.HttpInvokerSourceAdapter
 
initialize() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
initialize() - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
Subclasses may override this method for initialization.
initialize() - Method in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
initialize() - Method in class org.springframework.integration.bus.MessageBus
 
initialize() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
Subclasses may override this method for custom initialization requirements.
initialize() - Method in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
initialize() - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
initialized - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
initialized - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
initialized - Variable in class org.springframework.integration.bus.MessageBus
 
initialized - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
initialized - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
initialized - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
initialized - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
initializeTask() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
initializing - Variable in class org.springframework.integration.bus.MessageBus
 
initialValue() - Method in class org.springframework.integration.channel.ThreadLocalChannel.ThreadLocalMessageHolder
 
INPUT_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
IntegrationNamespaceHandler - Class in org.springframework.integration.config
Namespace handler for the integration namespace.
IntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.IntegrationNamespaceHandler
 
IntegrationNamespaceUtils - Class in org.springframework.integration.config
Shared utility methods for integration namespace parsers.
IntegrationNamespaceUtils() - Constructor for class org.springframework.integration.config.IntegrationNamespaceUtils
 
InterceptingMessageHandler - Class in org.springframework.integration.handler
A message handler implementation that intercepts calls to another handler.
InterceptingMessageHandler(MessageHandler) - Constructor for class org.springframework.integration.handler.InterceptingMessageHandler
 
INTERCEPTOR_ELEMENT - Static variable in class org.springframework.integration.channel.config.AbstractChannelParser
 
interceptors - Variable in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
INTERCEPTORS_PROPERTY - Static variable in class org.springframework.integration.channel.config.AbstractChannelParser
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Invoke the target method and publish its return value.
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
invokeMethod(Object...) - Method in class org.springframework.integration.util.DefaultMethodInvoker
 
invokeMethod(Object...) - Method in interface org.springframework.integration.util.MethodInvoker
 
invokeMethod(Object...) - Method in class org.springframework.integration.util.NameResolvingMethodInvoker
 
invoker - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
invoker - Variable in class org.springframework.integration.message.MethodInvokingSource
 
invoker - Variable in class org.springframework.integration.router.MessageListMethodAdapter
 
isActualTypeParameterizedMessage(Method) - Static method in class org.springframework.integration.router.MessageListMethodAdapter
 
isActualTypeRawMessage(Method) - Static method in class org.springframework.integration.router.MessageListMethodAdapter
 
isComplete(List<Message<?>>) - Method in interface org.springframework.integration.router.CompletionStrategy
 
isComplete(List<Message<?>>) - Method in class org.springframework.integration.router.CompletionStrategyAdapter
 
isComplete(List<Message<?>>) - Method in class org.springframework.integration.router.SequenceSizeCompletionStrategy
 
isEligibleAttribute(String) - Method in class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.adapter.file.config.FileSourceParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.adapter.file.config.FileTargetParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.adapter.rmi.config.RmiSourceAdapterParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.MessageBusParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.SourceEndpointParser
 
isEligibleAttribute(String) - Method in class org.springframework.integration.gateway.config.GatewayParser
 
isExpired() - Method in class org.springframework.integration.message.GenericMessage
 
isExpired() - Method in interface org.springframework.integration.message.Message
 
isHandlerAnnotation(Annotation) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
isHavingActualTypeArguments(Method) - Static method in class org.springframework.integration.router.MessageListMethodAdapter
 
isIced() - Method in class org.springframework.integration.samples.cafe.Drink
 
isMethodParameterParameterized(Method) - Static method in class org.springframework.integration.router.MessageListMethodAdapter
 
isPublishSubscribe() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return whether the dispatcher should attempt to publish to all of its handlers.
isRunning() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
isRunning() - Method in class org.springframework.integration.bus.MessageBus
 
isRunning() - Method in class org.springframework.integration.bus.SubscriptionManager
 
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.endpoint.TargetEndpoint
 
isRunning() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
isSingleton() - Method in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
isSingleton() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
isTextBased() - Method in class org.springframework.integration.adapter.ftp.FtpSource
 

J

JMS_TEMPLATE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
JMS_TEMPLATE_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
JmsAdapterParserUtils - Class in org.springframework.integration.adapter.jms.config
Utility methods and constants for JMS adapter parsers.
JmsAdapterParserUtils() - Constructor for class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
JmsAttributeKeys - Class in org.springframework.integration.adapter.jms
Keys to be used for setting and/or retrieving JMS attributes stored in the integration message header.
JmsAttributeKeys() - Constructor for class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
JmsGateway - Class in org.springframework.integration.adapter.jms
A message-driven adapter for receiving JMS messages and sending to a channel.
JmsGateway() - Constructor for class org.springframework.integration.adapter.jms.JmsGateway
 
JmsGatewayParser - Class in org.springframework.integration.adapter.jms.config
Parser for the <jms-gateway> element.
JmsGatewayParser() - Constructor for class org.springframework.integration.adapter.jms.config.JmsGatewayParser
 
JmsSource - Class in org.springframework.integration.adapter.jms
A source for receiving JMS Messages with a polling listener.
JmsSource(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.JmsSource
 
JmsSource(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.JmsSource
 
JmsSource(ConnectionFactory, String) - Constructor for class org.springframework.integration.adapter.jms.JmsSource
 
JmsSourceParser - Class in org.springframework.integration.adapter.jms.config
Parser for the <jms-source/> element.
JmsSourceParser() - Constructor for class org.springframework.integration.adapter.jms.config.JmsSourceParser
 
JmsTarget - Class in org.springframework.integration.adapter.jms
A target for sending JMS Messages.
JmsTarget(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.JmsTarget
 
JmsTarget(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.JmsTarget
 
JmsTarget(ConnectionFactory, String) - Constructor for class org.springframework.integration.adapter.jms.JmsTarget
 
JmsTarget() - Constructor for class org.springframework.integration.adapter.jms.JmsTarget
 
JmsTargetParser - Class in org.springframework.integration.adapter.jms.config
Parser for the <jms-target/> element.
JmsTargetParser() - Constructor for class org.springframework.integration.adapter.jms.config.JmsTargetParser
 
jmsTemplate - Variable in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 

K

KEEP_ALIVE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
keepAliveSeconds - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
key - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper.MethodParameterMetadata
 

L

lifecycleEndpoints - Variable in class org.springframework.integration.bus.MessageBus
 
lifecycleMonitor - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
lifecycleMonitor - Variable in class org.springframework.integration.bus.MessageBus
 
lifecycleMonitor - Variable in class org.springframework.integration.bus.SubscriptionManager
 
lifecycleMonitor - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
lifecycleTargets - Variable in class org.springframework.integration.bus.SubscriptionManager
 
listenerMonitor - Variable in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
listeners - Variable in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
loadAdapterParserMappings() - Method in class org.springframework.integration.config.IntegrationNamespaceHandler
 
localWorkingDirectory - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
lock - Variable in class org.springframework.integration.router.AggregationBarrier
 
log(Object) - Method in class org.springframework.integration.samples.quote.QuoteSubscriber
 
logger - Variable in class org.springframework.integration.adapter.file.AbstractFileMessageCreator
 
logger - Variable in class org.springframework.integration.adapter.file.FileSource
 
logger - Variable in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
logger - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
logger - Variable in class org.springframework.integration.adapter.jms.DefaultJmsHeaderMapper
 
logger - Variable in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
 
logger - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
logger - Variable in class org.springframework.integration.adapter.stream.ByteStreamTarget
 
logger - Variable in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
logger - Variable in class org.springframework.integration.aop.MessagePublishingInterceptor
 
logger - Variable in class org.springframework.integration.bus.DefaultErrorChannel
 
logger - Variable in class org.springframework.integration.bus.MessageBus
 
logger - Variable in class org.springframework.integration.bus.SubscriptionManager
 
logger - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
logger - Variable in class org.springframework.integration.channel.ChannelPublisher
 
logger - Variable in class org.springframework.integration.channel.interceptor.WireTap
 
logger - Variable in class org.springframework.integration.config.IntegrationNamespaceHandler
 
logger - Variable in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.dispatcher.SimpleDispatcher
 
logger - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
logger - Variable in class org.springframework.integration.endpoint.ConcurrentTarget
 
logger - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
logger - Variable in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
logger - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
logger - Variable in class org.springframework.integration.router.AggregationBarrier
 
logger - Variable in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
logger - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
logger - Variable in class org.springframework.integration.util.DefaultMethodInvoker
 
lookupChannel(String) - Method in class org.springframework.integration.bus.MessageBus
 
lookupChannel(String) - Method in interface org.springframework.integration.channel.ChannelRegistry
 
lookupChannel(String) - Method in class org.springframework.integration.channel.DefaultChannelRegistry
 
lookupEndpoint(String) - Method in class org.springframework.integration.bus.MessageBus
 
lookupEndpoint(String) - Method in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
lookupEndpoint(String) - Method in interface org.springframework.integration.endpoint.EndpointRegistry
 

M

MailAttributeKeys - Class in org.springframework.integration.adapter.mail
Keys to be used for setting and/or retrieving mail attributes stored in the integration message header.
MailAttributeKeys() - Constructor for class org.springframework.integration.adapter.mail.MailAttributeKeys
 
MailHeaderGenerator - Interface in org.springframework.integration.adapter.mail
Strategy interface for generating header information for an e-mail message from the content of the integration message.
mailHeaderGenerator - Variable in class org.springframework.integration.adapter.mail.MailTarget
 
mailSender - Variable in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
mailSender - Variable in class org.springframework.integration.adapter.mail.MailTarget
 
MailTarget - Class in org.springframework.integration.adapter.mail
A target adapter for sending mail.
MailTarget(JavaMailSender) - Constructor for class org.springframework.integration.adapter.mail.MailTarget
Create a MailTargetAdapter.
MailTarget.DefaultObjectMailMessageMapper - Class in org.springframework.integration.adapter.mail
 
MailTarget.DefaultObjectMailMessageMapper() - Constructor for class org.springframework.integration.adapter.mail.MailTarget.DefaultObjectMailMessageMapper
 
MailTargetParser - Class in org.springframework.integration.adapter.mail.config
Parser for the <mail-target/> element.
MailTargetParser() - Constructor for class org.springframework.integration.adapter.mail.config.MailTargetParser
 
main(String[]) - Static method in class org.springframework.integration.samples.cafe.CafeDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.filecopy.BinaryFileCopyDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.filecopy.FileBasedFileCopyDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.filecopy.TextFileCopyDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.helloworld.HelloWorldDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.oddeven.OddEvenDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.quote.QuoteDemo
 
main(String[]) - Static method in class org.springframework.integration.samples.ws.WebServiceDemo
 
map - Variable in class org.springframework.integration.message.SimpleMessageStore
 
mapFromMessageHeader(MessageHeader, Message) - Method in class org.springframework.integration.adapter.jms.DefaultJmsHeaderMapper
 
mapFromMessageHeader(MessageHeader, T) - Method in interface org.springframework.integration.adapter.MessageHeaderMapper
 
mapMessage(Message<T>) - Method in class org.springframework.integration.adapter.event.MessagingEventMapper
 
mapMessage(Message<Object>) - Method in class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
mapMessage(Message<byte[]>) - Method in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
mapMessage(Message<Object>) - Method in class org.springframework.integration.adapter.mail.MailTarget.DefaultObjectMailMessageMapper
 
mapMessage(Message<String>) - Method in class org.springframework.integration.adapter.mail.TextMailMessageMapper
 
mapMessage(Message) - Method in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
mapMessage(Message) - Method in class org.springframework.integration.message.DefaultMessageMapper
 
mapMessage(Message<P>) - Method in interface org.springframework.integration.message.MessageMapper
Map from the given Message to an Object.
mapper - Variable in class org.springframework.integration.adapter.event.ApplicationEventTarget
 
mapToMessageHeader(Message, MessageHeader) - Method in class org.springframework.integration.adapter.jms.DefaultJmsHeaderMapper
 
mapToMessageHeader(T, MessageHeader) - Method in interface org.springframework.integration.adapter.MessageHeaderMapper
 
MarshallingWebServiceTargetAdapter - Class in org.springframework.integration.ws.adapter
A marshalling Web Service target channel adapter.
MarshallingWebServiceTargetAdapter(URI, Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.adapter.MarshallingWebServiceTargetAdapter
 
MarshallingWebServiceTargetAdapter(URI, Marshaller) - Constructor for class org.springframework.integration.ws.adapter.MarshallingWebServiceTargetAdapter
 
matches(Method, Class) - Method in class org.springframework.integration.endpoint.SourceEndpoint.MethodNameAdvisor
 
MAX_SIZE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
maxConcurrentConsumers - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
maxMessagesPerTask - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
maxMessagesPerTask - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
maxSize - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
message - Variable in class org.springframework.integration.endpoint.ConcurrentTarget.TargetTask
 
Message<T> - Interface in org.springframework.integration.message
The central interface that any Message type must implement.
message - Variable in class org.springframework.integration.message.RetrievalBlockingMessageStore.MessageHolder
 
MESSAGE_BUS_AWARE_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.config.MessageBusParser
 
MESSAGE_BUS_BEAN_NAME - Static variable in class org.springframework.integration.config.MessageBusParser
 
MESSAGE_BUS_CLASS - Static variable in class org.springframework.integration.config.MessageBusParser
 
MESSAGE_CONVERTER_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
MESSAGE_CONVERTER_PROPERTY - Static variable in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
MESSAGE_CREATOR_REFERENCE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
MESSAGE_ENDPOINT_ANNOTATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.config.AnnotationDrivenParser
 
MessageBarrier - Interface in org.springframework.integration.router
Common interface for routing components that release a list of Messages based upon a condition that is met when a Message arrives.
MessageBus - Class in org.springframework.integration.bus
The messaging bus.
MessageBus() - Constructor for class org.springframework.integration.bus.MessageBus
 
messageBus - Variable in class org.springframework.integration.bus.MessageBusAwareBeanPostProcessor
 
messageBus - Variable in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
messageBus - Variable in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
MessageBusAware - Interface in org.springframework.integration.bus
Interface to be implemented by classes which need access to the MessageBus.
MessageBusAwareBeanPostProcessor - Class in org.springframework.integration.bus
A bean post processor which injects all MessageBusAware beans with a reference to the MessageBus.
MessageBusAwareBeanPostProcessor(MessageBus) - Constructor for class org.springframework.integration.bus.MessageBusAwareBeanPostProcessor
 
MessageBusParser - Class in org.springframework.integration.config
Parser for the message-bus element of the integration namespace.
MessageBusParser() - Constructor for class org.springframework.integration.config.MessageBusParser
 
MessageChannel - Interface in org.springframework.integration.channel
Base channel interface defining common behavior for message sending and receiving.
messageConverter - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
messageCreator - Variable in class org.springframework.integration.adapter.file.FileSource
 
messageCreator - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
messageCreator - Variable in class org.springframework.integration.aop.MessagePublishingInterceptor
 
messageCreator - Variable in class org.springframework.integration.gateway.SimpleMessagingGateway
 
messageCreator - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
MessageCreator<O,P> - Interface in org.springframework.integration.message
Strategy interface for creating a Message from an Object.
MessageDeliveryAware - Interface in org.springframework.integration.message
Interface that provides callback definitions for components that require message delivery status notifications.
MessageDeliveryException - Exception in org.springframework.integration.message
Exception that indicates an error during message delivery.
MessageDeliveryException(Message<?>) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDeliveryException(Message<?>, String) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDispatcher - Interface in org.springframework.integration.dispatcher
Strategy interface for dispatching messages.
MessageEndpoint - Annotation Type in org.springframework.integration.annotation
Indicates that a class is capable of serving as a message endpoint.
MessageEndpoint - Interface in org.springframework.integration.endpoint
Base interface for message endpoints.
MessageEndpointAnnotationPostProcessor - Class in org.springframework.integration.config
A BeanPostProcessor implementation that generates endpoints for classes annotated with @MessageEndpoint.
MessageEndpointAnnotationPostProcessor(MessageBus) - Constructor for class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
MessageFilter - Class in org.springframework.integration.transformer
Handler for deciding whether to pass a message.
MessageFilter(MessageSelector) - Constructor for class org.springframework.integration.transformer.MessageFilter
 
MessageHandler - Interface in org.springframework.integration.handler
Base message handler interface.
MessageHandlerChain - Class in org.springframework.integration.handler
A message handler implementation that passes incoming messages through a chain of handlers.
MessageHandlerChain() - Constructor for class org.springframework.integration.handler.MessageHandlerChain
 
MessageHandlerCreator - Interface in org.springframework.integration.handler.config
Strategy interface for creating MessageHandlers.
MessageHandlerNotRunningException - Exception in org.springframework.integration.handler
An exception indicating that a handler is not currently running.
MessageHandlerNotRunningException(Message<?>) - Constructor for exception org.springframework.integration.handler.MessageHandlerNotRunningException
 
MessageHandlerRejectedExecutionException - Exception in org.springframework.integration.handler
An exception indicating that a message was rejected by a handler; typically this would be the result of a thread pool executor rejecting a handler task.
MessageHandlerRejectedExecutionException(Message<?>) - Constructor for exception org.springframework.integration.handler.MessageHandlerRejectedExecutionException
 
MessageHandlerRejectedExecutionException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.handler.MessageHandlerRejectedExecutionException
 
MessageHandlingException - Exception in org.springframework.integration.message
Exception that indicates an error during message handling.
MessageHandlingException(Message<?>) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(Message<?>, String) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingSourceAdapter - Class in org.springframework.integration.adapter
A source adapter that implements the MessageHandler interface.
MessageHandlingSourceAdapter(MessageChannel) - Constructor for class org.springframework.integration.adapter.MessageHandlingSourceAdapter
Create an adapter that sends to the provided channel.
MessageHeader - Class in org.springframework.integration.message
A holder for Message metadata.
MessageHeader() - Constructor for class org.springframework.integration.message.MessageHeader
 
MessageHeaderMapper<T> - Interface in org.springframework.integration.adapter
Strategy interface for mapping between a source or target object and an integration MessageHeader.
messageHolder - Static variable in class org.springframework.integration.channel.ThreadLocalChannel
 
MessageListMethodAdapter - Class in org.springframework.integration.router
Base class for implementing adapters for methods which take as an argument a list of Message instances or payloads.
MessageListMethodAdapter(Object, String) - Constructor for class org.springframework.integration.router.MessageListMethodAdapter
 
MessageListMethodAdapter(Object, Method) - Constructor for class org.springframework.integration.router.MessageListMethodAdapter
 
messageMapper - Variable in class org.springframework.integration.adapter.file.FileTarget
 
messageMapper - Variable in class org.springframework.integration.gateway.SimpleMessagingGateway
 
messageMapper - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
MessageMapper<P,O> - Interface in org.springframework.integration.message
Strategy interface for mapping from a Message to an Object.
MessageMappingException - Exception in org.springframework.integration.adapter
Exception that indicates an error during message mapping.
MessageMappingException(Message<?>, String) - Constructor for exception org.springframework.integration.adapter.MessageMappingException
 
MessageMappingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.adapter.MessageMappingException
 
MessagePriority - Enum in org.springframework.integration.message
An enumeration of the possible values for a message's priority.
MessagePriority() - Constructor for enum org.springframework.integration.message.MessagePriority
 
MessagePublishingErrorHandler - Class in org.springframework.integration.scheduling
ErrorHandler implementation that sends an ErrorMessage to a MessageChannel.
MessagePublishingErrorHandler() - Constructor for class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
MessagePublishingErrorHandler(MessageChannel) - Constructor for class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
MessagePublishingInterceptor - Class in org.springframework.integration.aop
Interceptor that publishes a target method's return value to a channel.
MessagePublishingInterceptor() - Constructor for class org.springframework.integration.aop.MessagePublishingInterceptor
 
messages - Variable in class org.springframework.integration.router.AggregationBarrier
 
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.message.selector
Strategy interface for message selection.
MessageSelectorChain - Class in org.springframework.integration.message.selector
A message selector implementation that passes incoming messages through a chain of selectors.
MessageSelectorChain() - Constructor for class org.springframework.integration.message.selector.MessageSelectorChain
 
MessageSequenceComparator - Class in org.springframework.integration.router
A Comparator implementation based on the 'sequenceNumber' property of a Message's header.
MessageSequenceComparator() - Constructor for class org.springframework.integration.router.MessageSequenceComparator
 
messageStore - Variable in class org.springframework.integration.handler.ReplyMessageCorrelator
 
MessageStore - Interface in org.springframework.integration.message
Strategy interface for storing and retrieving messages.
MessagingEvent<T> - Class in org.springframework.integration.adapter.event
A subclass of ApplicationEvent that wraps a Message.
MessagingEvent(Message<T>) - Constructor for class org.springframework.integration.adapter.event.MessagingEvent
 
MessagingEventMapper<T> - Class in org.springframework.integration.adapter.event
Maps between Messages and MessagingEvents.
MessagingEventMapper() - Constructor for class org.springframework.integration.adapter.event.MessagingEventMapper
 
MessagingException - Exception in org.springframework.integration.message
The base exception for any failures within the messaging system.
MessagingException(Message<?>) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingException(String) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingException(String, Throwable) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingException(Message<?>, String) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.message.MessagingException
 
MessagingGatewaySupport - Class in org.springframework.integration.gateway
A convenient base class providing access to a RequestReplyTemplate and exposing setter methods for configuring request and reply MessageChannels.
MessagingGatewaySupport(MessageChannel) - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
 
MessagingGatewaySupport() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
 
MessagingTask - Interface in org.springframework.integration.scheduling
An extension of runnable that provides metadata for a MessagingTaskScheduler.
MessagingTaskScheduler - Interface in org.springframework.integration.scheduling
Base interface for MessagingTask schedulers.
method - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
method - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
method - Variable in class org.springframework.integration.message.MethodInvokingSource
 
method - Variable in class org.springframework.integration.router.MessageListMethodAdapter
 
method - Variable in class org.springframework.integration.util.DefaultMethodInvoker
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
METHOD_NAME_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
methodExpectsMessage - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
MethodInvoker - Interface in org.springframework.integration.util
A strategy interface for invoking a method.
MethodInvokingAdapterParser - Class in org.springframework.integration.config
Parser for <source-adapter> and <target-adapter>.
MethodInvokingAdapterParser() - Constructor for class org.springframework.integration.config.MethodInvokingAdapterParser
 
MethodInvokingSource - Class in org.springframework.integration.message
A pollable source that invokes a no-argument method so that its return value may be sent to a channel.
MethodInvokingSource() - Constructor for class org.springframework.integration.message.MethodInvokingSource
 
MethodInvokingSource.MessageReceivingMethodValidator - Class in org.springframework.integration.message
 
MethodInvokingSource.MessageReceivingMethodValidator() - Constructor for class org.springframework.integration.message.MethodInvokingSource.MessageReceivingMethodValidator
 
MethodInvokingTarget - Class in org.springframework.integration.handler
A messaging target that invokes the specified method on the provided object.
MethodInvokingTarget() - Constructor for class org.springframework.integration.handler.MethodInvokingTarget
 
methodName - Variable in class org.springframework.integration.endpoint.SourceEndpoint.MethodNameAdvisor
 
methodName - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
methodName - Variable in class org.springframework.integration.util.NameResolvingMethodInvoker
 
MethodValidator - Interface in org.springframework.integration.util
Interface for method validation.
methodValidator - Variable in class org.springframework.integration.util.NameResolvingMethodInvoker
 
modificationTimestamp - Variable in class org.springframework.integration.adapter.ftp.FileInfo
 
monitor - Variable in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
MultiChannelNameResolver - Interface in org.springframework.integration.router
Strategy interface for content-based routing to multiple channel names.
MultiChannelResolver - Interface in org.springframework.integration.router
Strategy interface for content-based routing to multiple channels.
MultiChannelRouter - Class in org.springframework.integration.router
A router implementation for sending to potentially multiple MessageChannels.
MultiChannelRouter() - Constructor for class org.springframework.integration.router.MultiChannelRouter
 
multipartMode - Variable in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 

N

name - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
name - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
NAME_GENERATOR_PROPERTY - Static variable in class org.springframework.integration.adapter.file.config.FileTargetParser
 
NameResolvingMethodInvoker - Class in org.springframework.integration.util
Implementation of MethodInvoker to be used when only the method name is known.
NameResolvingMethodInvoker(Object, String) - Constructor for class org.springframework.integration.util.NameResolvingMethodInvoker
 
NumberLogger - Class in org.springframework.integration.samples.oddeven
 
NumberLogger() - Constructor for class org.springframework.integration.samples.oddeven.NumberLogger
 

O

object - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
object - Variable in class org.springframework.integration.message.MethodInvokingSource
 
object - Variable in class org.springframework.integration.util.DefaultMethodInvoker
 
object - Variable in class org.springframework.integration.util.NameResolvingMethodInvoker
 
OBJECT_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
objectMessageMapper - Variable in class org.springframework.integration.adapter.mail.MailTarget
 
odd(int) - Method in class org.springframework.integration.samples.oddeven.NumberLogger
 
OddEvenDemo - Class in org.springframework.integration.samples.oddeven
 
OddEvenDemo() - Constructor for class org.springframework.integration.samples.oddeven.OddEvenDemo
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.adapter.event.ApplicationEventSource
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.bus.MessageBus
 
onFailure(MessagingException) - Method in class org.springframework.integration.adapter.file.FileSource
 
onFailure(MessagingException) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
onFailure(MessagingException) - Method in interface org.springframework.integration.message.MessageDeliveryAware
Callback method invoked after a message delivery failure.
onMessage(Message) - Method in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
onSend(Message<?>) - Method in class org.springframework.integration.adapter.file.FileSource
 
onSend(Message<?>) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
onSend(Message<?>) - Method in interface org.springframework.integration.message.MessageDeliveryAware
Callback method invoked after a message is sent successfully.
orderChannel - Variable in class org.springframework.integration.samples.cafe.Cafe
 
OrderSplitter - Class in org.springframework.integration.samples.cafe
 
OrderSplitter() - Constructor for class org.springframework.integration.samples.cafe.OrderSplitter
 
org.springframework.integration - package org.springframework.integration
 
org.springframework.integration.adapter - package org.springframework.integration.adapter
 
org.springframework.integration.adapter.config - package org.springframework.integration.adapter.config
 
org.springframework.integration.adapter.event - package org.springframework.integration.adapter.event
 
org.springframework.integration.adapter.file - package org.springframework.integration.adapter.file
 
org.springframework.integration.adapter.file.config - package org.springframework.integration.adapter.file.config
 
org.springframework.integration.adapter.ftp - package org.springframework.integration.adapter.ftp
 
org.springframework.integration.adapter.ftp.config - package org.springframework.integration.adapter.ftp.config
 
org.springframework.integration.adapter.httpinvoker - package org.springframework.integration.adapter.httpinvoker
 
org.springframework.integration.adapter.httpinvoker.config - package org.springframework.integration.adapter.httpinvoker.config
 
org.springframework.integration.adapter.jms - package org.springframework.integration.adapter.jms
 
org.springframework.integration.adapter.jms.config - package org.springframework.integration.adapter.jms.config
 
org.springframework.integration.adapter.mail - package org.springframework.integration.adapter.mail
 
org.springframework.integration.adapter.mail.config - package org.springframework.integration.adapter.mail.config
 
org.springframework.integration.adapter.rmi - package org.springframework.integration.adapter.rmi
 
org.springframework.integration.adapter.rmi.config - package org.springframework.integration.adapter.rmi.config
 
org.springframework.integration.adapter.stream - package org.springframework.integration.adapter.stream
 
org.springframework.integration.adapter.stream.config - package org.springframework.integration.adapter.stream.config
 
org.springframework.integration.annotation - package org.springframework.integration.annotation
 
org.springframework.integration.aop - package org.springframework.integration.aop
 
org.springframework.integration.bus - package org.springframework.integration.bus
 
org.springframework.integration.channel - package org.springframework.integration.channel
 
org.springframework.integration.channel.config - package org.springframework.integration.channel.config
 
org.springframework.integration.channel.factory - package org.springframework.integration.channel.factory
 
org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
 
org.springframework.integration.config - package org.springframework.integration.config
 
org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
 
org.springframework.integration.endpoint - package org.springframework.integration.endpoint
 
org.springframework.integration.gateway - package org.springframework.integration.gateway
 
org.springframework.integration.gateway.config - package org.springframework.integration.gateway.config
 
org.springframework.integration.handler - package org.springframework.integration.handler
 
org.springframework.integration.handler.annotation - package org.springframework.integration.handler.annotation
 
org.springframework.integration.handler.config - package org.springframework.integration.handler.config
 
org.springframework.integration.message - package org.springframework.integration.message
 
org.springframework.integration.message.selector - package org.springframework.integration.message.selector
 
org.springframework.integration.router - package org.springframework.integration.router
 
org.springframework.integration.router.config - package org.springframework.integration.router.config
 
org.springframework.integration.samples.cafe - package org.springframework.integration.samples.cafe
 
org.springframework.integration.samples.filecopy - package org.springframework.integration.samples.filecopy
 
org.springframework.integration.samples.helloworld - package org.springframework.integration.samples.helloworld
 
org.springframework.integration.samples.oddeven - package org.springframework.integration.samples.oddeven
 
org.springframework.integration.samples.quote - package org.springframework.integration.samples.quote
 
org.springframework.integration.samples.ws - package org.springframework.integration.samples.ws
 
org.springframework.integration.scheduling - package org.springframework.integration.scheduling
 
org.springframework.integration.test - package org.springframework.integration.test
 
org.springframework.integration.transformer - package org.springframework.integration.transformer
 
org.springframework.integration.util - package org.springframework.integration.util
 
org.springframework.integration.ws.adapter - package org.springframework.integration.ws.adapter
 
org.springframework.integration.ws.config - package org.springframework.integration.ws.config
 
ORIGINAL_MESSAGE_ID_KEY - Static variable in class org.springframework.integration.channel.interceptor.WireTap
key for the attribute containing the original Message's id
originalMessage - Variable in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
OUTPUT_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.HandlerEndpointParser
 
OUTPUT_CHANNEL_NAME_KEY - Static variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
OUTPUT_CHANNEL_PROPERTY - Static variable in class org.springframework.integration.config.HandlerEndpointParser
 
outputChannelName - Variable in class org.springframework.integration.endpoint.HandlerEndpoint
 
outputChannelName - Variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 

P

parameterMetadata - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
parameterNameDiscoverer - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
parentDirectory - Variable in class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.AggregatorParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.HandlerParser
 
parseAcknowledgeMode(Element) - Static method in class org.springframework.integration.adapter.jms.config.JmsAdapterParserUtils
 
parseAdapter(String, String, ParserContext) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
parseAggregatorElement(Element, ParserContext, boolean) - Method in class org.springframework.integration.config.AggregatorParser
 
parseConcurrencyPolicy(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
parseConcurrencyPolicy(Element) - Static method in class org.springframework.integration.config.IntegrationNamespaceUtils
 
parseHandler(Element, ParserContext, ManagedList) - Method in class org.springframework.integration.config.HandlerParser
 
parseHandlerAdapter(String, String, String, ParserContext, boolean) - Method in class org.springframework.integration.config.HandlerParser
 
parseHandlerChain(Element, ParserContext) - Method in class org.springframework.integration.config.HandlerParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.adapter.jms.config.JmsSourceParser
 
parseMarshallingAdapter(String, String, String) - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
parseSchedule(Element) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
parseSchedule(Element) - Method in class org.springframework.integration.config.SourceEndpointParser
Subclasses may override this method to control the creation of the Schedule.
parseSimpleAdapter(String, String) - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
parseTarget(Element, String, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
password - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
payload - Variable in class org.springframework.integration.message.GenericMessage
 
PayloadTypeRouter - Class in org.springframework.integration.router
A router implementation that resolves the MessageChannel based on the Message's payload type.
PayloadTypeRouter() - Constructor for class org.springframework.integration.router.PayloadTypeRouter
 
PayloadTypeRouter.PayloadTypeChannelResolver - Class in org.springframework.integration.router
 
PayloadTypeRouter.PayloadTypeChannelResolver() - Constructor for class org.springframework.integration.router.PayloadTypeRouter.PayloadTypeChannelResolver
 
PayloadTypeSelector - Class in org.springframework.integration.message.selector
A MessageSelector implementation that checks the type of the Message payload.
PayloadTypeSelector(Class<?>...) - Constructor for class org.springframework.integration.message.selector.PayloadTypeSelector
Create a selector for the provided types.
pendingTasks - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
period - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
PERIOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
placeOrder(DrinkOrder) - Method in class org.springframework.integration.samples.cafe.Cafe
 
pointcut - Variable in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
poll() - Method in class org.springframework.integration.dispatcher.DefaultPollingDispatcher
 
poll() - Method in interface org.springframework.integration.message.Poller
 
Polled - Annotation Type in org.springframework.integration.annotation
Annotation that can be specified at class-level alongside a @MessageEndpoint annotation in order to provide the scheduling information for that endpoint.
Poller - Interface in org.springframework.integration.message
 
PollingDispatcher - Interface in org.springframework.integration.dispatcher
 
PollingDispatcherTask - Class in org.springframework.integration.dispatcher
A MessagingTask that combines polling and dispatching.
PollingDispatcherTask(PollingDispatcher, Schedule) - Constructor for class org.springframework.integration.dispatcher.PollingDispatcherTask
 
PollingSchedule - Class in org.springframework.integration.scheduling
Scheduling metadata for a polling task.
PollingSchedule(long) - Constructor for class org.springframework.integration.scheduling.PollingSchedule
Create a fixed-delay schedule with no initial delay.
populateMailMessageHeader(MailMessage, Message<?>) - Method in class org.springframework.integration.adapter.mail.AbstractMailHeaderGenerator
Populate the mail message using the results of the template methods.
populateMailMessageHeader(MailMessage, Message<?>) - Method in interface org.springframework.integration.adapter.mail.MailHeaderGenerator
Populate the e-mail message header based on the content of the integration message.
port - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.adapter.file.config.FileSourceParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.HandlerEndpointParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.MessageBusParser
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.gateway.config.GatewayParser
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.bus.MessageBusAwareBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.bus.MessageBusAwareBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
postReceive(Message<?>, MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.bus.DefaultErrorChannel.ErrorLoggingInterceptor
 
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
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
prefersShortLivedTasks() - Method in class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
 
prepareColdDrink(Drink) - Method in class org.springframework.integration.samples.cafe.Barista
 
prepareHotDrink(Drink) - Method in class org.springframework.integration.samples.cafe.Barista
 
prepareMessage(Message<?>, Object, int, int) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
preReceive(MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preReceive(MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
 
preReceive(MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ChannelInterceptorAdapter
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.bus.DefaultErrorChannel.ErrorLoggingInterceptor
Even if the error channel has no subscribers, errors are at least visible at debug level.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preSend(Message<?>, MessageChannel) - Method in interface org.springframework.integration.channel.ChannelInterceptor
 
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
 
previousSnapshot - Variable in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
price - Variable in class org.springframework.integration.samples.quote.Quote
 
priority - Variable in class org.springframework.integration.message.MessageHeader
 
PriorityChannel - Class in org.springframework.integration.channel
A message channel that prioritizes messages based on a PriorityChannel.MessagePriorityComparator.
PriorityChannel(int, DispatcherPolicy, Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity and dispatcher policy.
PriorityChannel(int, DispatcherPolicy) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity and dispatcher policy.
PriorityChannel(int) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity and default dispatcher policy.
PriorityChannel() - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the default queue capacity and dispatcher policy.
PriorityChannel.MessagePriorityComparator - Class in org.springframework.integration.channel
 
PriorityChannel.MessagePriorityComparator() - Constructor for class org.springframework.integration.channel.PriorityChannel.MessagePriorityComparator
 
PriorityChannelFactory - Class in org.springframework.integration.channel.factory
A ChannelFactory for creating PriorityChannel instances.
PriorityChannelFactory() - Constructor for class org.springframework.integration.channel.factory.PriorityChannelFactory
 
PriorityChannelParser - Class in org.springframework.integration.channel.config
Parser for the <priority-channel> element.
PriorityChannelParser() - Constructor for class org.springframework.integration.channel.config.PriorityChannelParser
 
processChildElements(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.MessageBusParser
 
processSnapshot(Map<String, FileInfo>) - Method in class org.springframework.integration.adapter.ftp.DirectoryContentManager
 
properties - Variable in class org.springframework.integration.message.MessageHeader
 
publish(Message<?>) - Method in class org.springframework.integration.channel.ChannelPublisher
 
PUBLISH_SUBSCRIBE_ATTRIBUTE - Static variable in class org.springframework.integration.channel.config.AbstractChannelParser
 
Publisher - Annotation Type in org.springframework.integration.annotation
Indicates that the method's return value should be published to the specified channel.
PUBLISHER_ANNOTATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.config.AnnotationDrivenParser
 
PublisherAnnotationAdvisor - Class in org.springframework.integration.aop
Advisor whose pointcut matches a method annotation and whose advice will publish a message to the channel provided by that annotation.
PublisherAnnotationAdvisor(ChannelRegistry) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationAdvisor(Class<? extends Annotation>, String, ChannelRegistry) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationPostProcessor - Class in org.springframework.integration.config
A BeanPostProcessor that adds a message publishing interceptor when it discovers annotated methods.
PublisherAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
publisherAnnotationType - Variable in class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
publisherAnnotationType - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
publishSubscribe - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
purge() - Method in class org.springframework.integration.channel.ChannelPurger
 
purge(MessageSelector) - Method in interface org.springframework.integration.channel.MessageChannel
Remove any Messages that are not accepted by the provided selector.
purge(MessageSelector) - Method in class org.springframework.integration.channel.QueueChannel
 
purge(MessageSelector) - Method in class org.springframework.integration.channel.ThreadLocalChannel
Remove and return any messages that are stored for the current thread and do not match the provided selector.
purge(MessageSelector) - Method in class org.springframework.integration.dispatcher.DirectChannel
 
purge(MessageSelector) - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
put(Object, Message<?>) - Method in interface org.springframework.integration.message.MessageStore
 
put(Object, Message<?>) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
put(Object, Message<?>) - Method in class org.springframework.integration.message.SimpleMessageStore
 

Q

queue - Variable in class org.springframework.integration.channel.QueueChannel
 
QUEUE_CAPACITY_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
queueCapacity - Variable in class org.springframework.integration.channel.factory.QueueChannelFactory
 
queueCapacity - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
QueueChannel - Class in org.springframework.integration.channel
Simple implementation of a message channel.
QueueChannel(BlockingQueue<Message<?>>, DispatcherPolicy) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue and dispatcher policy.
QueueChannel(int, DispatcherPolicy) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue capacity and dispatcher policy.
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 the default queue capacity.
QueueChannelFactory - Class in org.springframework.integration.channel.factory
Default implementation of a ChannelFactory, which will create instances of a QueueChannel.
QueueChannelFactory() - Constructor for class org.springframework.integration.channel.factory.QueueChannelFactory
 
QueueChannelParser - Class in org.springframework.integration.channel.config
Parser for the <queue-channel> element.
QueueChannelParser() - Constructor for class org.springframework.integration.channel.config.QueueChannelParser
 
Quote - Class in org.springframework.integration.samples.quote
 
Quote(String, BigDecimal) - Constructor for class org.springframework.integration.samples.quote.Quote
 
QuoteDemo - Class in org.springframework.integration.samples.quote
 
QuoteDemo() - Constructor for class org.springframework.integration.samples.quote.QuoteDemo
 
QuotePublisher - Class in org.springframework.integration.samples.quote
 
QuotePublisher() - Constructor for class org.springframework.integration.samples.quote.QuotePublisher
 
QuoteSubscriber - Class in org.springframework.integration.samples.quote
 
QuoteSubscriber() - Constructor for class org.springframework.integration.samples.quote.QuoteSubscriber
 

R

RandomUuidGenerator - Class in org.springframework.integration.util
An id generator that generates random UUIDs.
RandomUuidGenerator() - Constructor for class org.springframework.integration.util.RandomUuidGenerator
 
reader - Variable in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.AbstractFileMessageCreator
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.ByteArrayFileMessageCreator
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.FileMessageCreator
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.TextFileMessageCreator
 
REAPER_INTERVAL - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
REAPER_INTERVAL_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
REAPER_INTERVAL_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
reaperInterval - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
receive() - Method in class org.springframework.integration.adapter.file.FileSource
 
receive() - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
receive() - Method in class org.springframework.integration.adapter.jms.JmsSource
 
receive() - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
receive() - Method in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
receive() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Receive the first available message from this channel.
receive(long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Receive the first available message from this channel.
receive() - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
receive() - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
receive(long) - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
receive() - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
receive() - Method in interface org.springframework.integration.message.BlockingSource
Receive a message, blocking indefinitely if necessary.
receive(long) - Method in interface org.springframework.integration.message.BlockingSource
Receive a message, blocking until either a message is available or the specified timeout period elapses.
receive() - Method in class org.springframework.integration.message.MethodInvokingSource
 
receive() - Method in interface org.springframework.integration.message.Source
Retrieve a message from this source or null if no message is available.
receiveResponse(MessageChannel) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
receiveTimeout - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
RecipientListRouter - Class in org.springframework.integration.router
A simple extension of MultiChannelRouter that routes to a statically configured list of recipients.
RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
 
RecipientListRouter.RecipientListChannelNameResolver - Class in org.springframework.integration.router
 
RecipientListRouter.RecipientListChannelNameResolver(String[]) - Constructor for class org.springframework.integration.router.RecipientListRouter.RecipientListChannelNameResolver
 
RecipientListRouter.RecipientListChannelResolver - Class in org.springframework.integration.router
 
RecipientListRouter.RecipientListChannelResolver(List<MessageChannel>) - Constructor for class org.springframework.integration.router.RecipientListRouter.RecipientListChannelResolver
 
REDELIVERED - Static variable in class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
referenceAttributes - Static variable in class org.springframework.integration.gateway.config.GatewayParser
 
refreshTask() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
registerChannel(String, MessageChannel) - Method in class org.springframework.integration.bus.MessageBus
 
registerChannel(String, MessageChannel) - Method in interface org.springframework.integration.channel.ChannelRegistry
 
registerChannel(String, MessageChannel) - Method in class org.springframework.integration.channel.DefaultChannelRegistry
 
registerChannels(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
registerEndpoint(String, MessageEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
registerEndpoint(String, MessageEndpoint) - Method in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
registerEndpoint(String, MessageEndpoint) - Method in interface org.springframework.integration.endpoint.EndpointRegistry
 
registerEndpoints(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
registerHandler(String, MessageHandler, Subscription) - Method in class org.springframework.integration.bus.MessageBus
 
registerHandler(String, MessageHandler, Subscription, ConcurrencyPolicy) - Method in class org.springframework.integration.bus.MessageBus
 
registerReplyMessageCorrelator() - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
registerSourceEndpoint(String, SourceEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
registerTarget(String, Target, Subscription) - Method in class org.springframework.integration.bus.MessageBus
 
registerTarget(String, Target, Subscription, ConcurrencyPolicy) - Method in class org.springframework.integration.bus.MessageBus
 
registerTargetEndpoint(String, TargetEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
registryHost - Variable in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
registryPort - Variable in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
rejectionLimit - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
REMOTE_INVOCATION_EXECUTOR_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.rmi.config.RmiSourceAdapterParser
 
remoteInvocationExecutor - Variable in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
remoteWorkingDirectory - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
remove(Object) - Method in interface org.springframework.integration.message.MessageStore
 
remove(Object) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
remove(Object, long) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
remove(Object) - Method in class org.springframework.integration.message.SimpleMessageStore
 
removeAttribute(String) - Method in class org.springframework.integration.message.MessageHeader
 
removeBarrier(Object) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
removeEldestEntry(Map.Entry<K, V>) - Method in class org.springframework.integration.util.BoundedHashMap
 
removeProperty(String) - Method in class org.springframework.integration.message.MessageHeader
 
removeTarget(Target) - Method in class org.springframework.integration.bus.SubscriptionManager
 
RendezvousChannel - Class in org.springframework.integration.channel
A zero-capacity version of QueueChannel that delegates to a SynchronousQueue internally.
RendezvousChannel(DispatcherPolicy) - Constructor for class org.springframework.integration.channel.RendezvousChannel
 
RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
 
RendezvousChannelFactory - Class in org.springframework.integration.channel.factory
A ChannelFactory for creating RendezvousChannel instances.
RendezvousChannelFactory() - Constructor for class org.springframework.integration.channel.factory.RendezvousChannelFactory
 
RendezvousChannelParser - Class in org.springframework.integration.channel.config
Parser for the <rendezvous-channel> element.
RendezvousChannelParser() - Constructor for class org.springframework.integration.channel.config.RendezvousChannelParser
 
REPLY_HANDLER_ATTRIBUTE - Static variable in class org.springframework.integration.config.HandlerEndpointParser
 
REPLY_HANDLER_PROPERTY - Static variable in class org.springframework.integration.config.HandlerEndpointParser
 
REPLY_TO - Static variable in class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
REPLY_TO - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
replyChannel - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
replyHandler - Variable in class org.springframework.integration.endpoint.HandlerEndpoint.HandlerInvokingTarget
 
replyHandler - Variable in class org.springframework.integration.endpoint.HandlerEndpoint
 
replyHandler - Variable in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
ReplyHandler - Interface in org.springframework.integration.handler
Strategy interface for handling reply messages.
replyMessageCorrelator - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
ReplyMessageCorrelator - Class in org.springframework.integration.handler
A handler for receiving messages from a "reply channel".
ReplyMessageCorrelator(int) - Constructor for class org.springframework.integration.handler.ReplyMessageCorrelator
 
replyMessageCorrelatorMonitor - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
replyTimeout - Variable in class org.springframework.integration.endpoint.HandlerEndpoint
 
replyTimeout - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
replyTo - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
request(Message<?>, ReplyHandler) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Send a request message whose reply should be handled be the provided callback.
request(Message<?>) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Send a request message and wait for a reply message using the configured timeout values.
requestCallback - Variable in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
requestChannel - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
requestChannel - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
requestReplyTemplate - Variable in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
requestReplyTemplate - Variable in class org.springframework.integration.gateway.MessagingGatewaySupport
 
RequestReplyTemplate - Class in org.springframework.integration.gateway
A template that facilitates the implementation of request-reply usage scenarios above one-way MessageChannels.
RequestReplyTemplate(MessageChannel, MessageChannel) - Constructor for class org.springframework.integration.gateway.RequestReplyTemplate
Create a RequestReplyTemplate.
RequestReplyTemplate(MessageChannel) - Constructor for class org.springframework.integration.gateway.RequestReplyTemplate
Create a RequestReplyTemplate that will use anonymous temporary channels for replies.
RequestReplyTemplate() - Constructor for class org.springframework.integration.gateway.RequestReplyTemplate
 
RequestReplyTemplate.ReplyHandlingChannelAdapter - Class in org.springframework.integration.gateway
 
RequestReplyTemplate.ReplyHandlingChannelAdapter(Message<?>, ReplyHandler) - Constructor for class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
requestTimeout - Variable in class org.springframework.integration.gateway.RequestReplyTemplate
 
required - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper.MethodParameterMetadata
 
resolutionRequired - Variable in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
resolve(Message<?>) - Method in interface org.springframework.integration.router.ChannelNameResolver
 
resolve(Message<?>) - Method in interface org.springframework.integration.router.ChannelResolver
 
resolve(Message<?>) - Method in interface org.springframework.integration.router.MultiChannelNameResolver
 
resolve(Message<?>) - Method in interface org.springframework.integration.router.MultiChannelResolver
 
resolve(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter.PayloadTypeChannelResolver
 
resolve(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter.RecipientListChannelNameResolver
 
resolve(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter.RecipientListChannelResolver
 
resolve(Message<?>) - Method in class org.springframework.integration.router.RootCauseErrorMessageRouter.RootCauseResolver
 
resolveChannel(MethodInvocation) - Method in class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
resolveChannel(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Subclasses may override this method to provide custom behavior.
resolveChannel(Message<?>) - Method in class org.springframework.integration.router.SingleChannelRouter
 
resolveChannel(int) - Method in class org.springframework.integration.samples.oddeven.Counter
 
resolveChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
resolveChannels(Message<?>) - Method in class org.springframework.integration.router.MultiChannelRouter
 
resolveChannels(Message<?>) - Method in class org.springframework.integration.router.SingleChannelRouter
 
resolveDrinkChannel(Drink) - Method in class org.springframework.integration.samples.cafe.DrinkRouter
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.adapter.config.AbstractRequestReplySourceAdapterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.MessageBusParser
 
resolveParameterNameIfNecessary(String, MethodParameter) - Method in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper
 
resolveReplyChannel(MessageHeader) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
resolveReplyChannelFromMessage(Message<?>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
RetrievalBlockingMessageStore - Class in org.springframework.integration.message
A MessageStore implementation whose get and remove methods block until a message is available.
RetrievalBlockingMessageStore(MessageStore) - Constructor for class org.springframework.integration.message.RetrievalBlockingMessageStore
Create a wrapper for the provided MessageStore so that its retrieval methods will block.
RetrievalBlockingMessageStore(int) - Constructor for class org.springframework.integration.message.RetrievalBlockingMessageStore
Create a wrapper for a SimpleMessageStore so that its retrieval methods will block.
RetrievalBlockingMessageStore.MessageHolder - Class in org.springframework.integration.message
A wrapper class to enable null messages in the queue.
RetrievalBlockingMessageStore.MessageHolder(Message<?>) - Constructor for class org.springframework.integration.message.RetrievalBlockingMessageStore.MessageHolder
 
retrieveAsString(Message<?>, String) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
retrieveAsStringArray(Message<?>, String) - Method in class org.springframework.integration.adapter.mail.DefaultMailHeaderGenerator
 
retryInterval - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
RETURN_ADDRESS_OVERRIDES_ATTRIBUTE - Static variable in class org.springframework.integration.config.HandlerEndpointParser
 
returnAddress - Variable in class org.springframework.integration.message.MessageHeader
 
returnAddressOverrides - Variable in class org.springframework.integration.endpoint.HandlerEndpoint
 
RmiSourceAdapter - Class in org.springframework.integration.adapter.rmi
A source channel adapter for RMI-based remoting.
RmiSourceAdapter(MessageChannel) - Constructor for class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
RmiSourceAdapterParser - Class in org.springframework.integration.adapter.rmi.config
Parser for the <rmi-source/> element.
RmiSourceAdapterParser() - Constructor for class org.springframework.integration.adapter.rmi.config.RmiSourceAdapterParser
 
RmiTargetAdapter - Class in org.springframework.integration.adapter.rmi
A target channel adapter for RMI-based remoting.
RmiTargetAdapter(String) - Constructor for class org.springframework.integration.adapter.rmi.RmiTargetAdapter
 
RmiTargetAdapterParser - Class in org.springframework.integration.adapter.rmi.config
Parser for the <rmi-target/> element.
RmiTargetAdapterParser() - Constructor for class org.springframework.integration.adapter.rmi.config.RmiTargetAdapterParser
 
RootCauseErrorMessageRouter - Class in org.springframework.integration.router
A router implementation that resolves the MessageChannel for messages whose payload is an Exception.
RootCauseErrorMessageRouter() - Constructor for class org.springframework.integration.router.RootCauseErrorMessageRouter
 
RootCauseErrorMessageRouter.RootCauseResolver - Class in org.springframework.integration.router
 
RootCauseErrorMessageRouter.RootCauseResolver() - Constructor for class org.springframework.integration.router.RootCauseErrorMessageRouter.RootCauseResolver
 
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 payload, message attribute, or message property.
RouterMessageHandlerAdapter - Class in org.springframework.integration.router
MessageHandler adapter for methods annotated with @Router.
RouterMessageHandlerAdapter(Object, Method) - Constructor for class org.springframework.integration.router.RouterMessageHandlerAdapter
 
RouterMessageHandlerAdapter(Object, String) - Constructor for class org.springframework.integration.router.RouterMessageHandlerAdapter
 
RouterMessageHandlerCreator - Class in org.springframework.integration.router.config
Creates a MessageHandler adapter for router methods.
RouterMessageHandlerCreator() - Constructor for class org.springframework.integration.router.config.RouterMessageHandlerCreator
 
RouterParser - Class in org.springframework.integration.router.config
Parser for the <router/> element.
RouterParser() - Constructor for class org.springframework.integration.router.config.RouterParser
 
run() - Method in class org.springframework.integration.dispatcher.PollingDispatcherTask
 
run() - Method in class org.springframework.integration.endpoint.ConcurrentTarget.TargetTask
 
run() - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
run() - Method in class org.springframework.integration.router.AggregatingMessageHandler.ReaperTask
 
run() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
running - Variable in class org.springframework.integration.bus.MessageBus
 
running - Variable in class org.springframework.integration.bus.SubscriptionManager
 
running - Variable in class org.springframework.integration.channel.interceptor.WireTap
 
running - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
running - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 

S

sayHello(String) - Method in class org.springframework.integration.samples.helloworld.HelloService
 
schedule - Variable in class org.springframework.integration.dispatcher.PollingDispatcherTask
 
schedule - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
schedule(Runnable) - Method in class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
 
schedule(Runnable) - Method in interface org.springframework.integration.scheduling.MessagingTaskScheduler
 
Schedule - Interface in org.springframework.integration.scheduling
A marker interface for scheduling metadata.
schedule(Runnable) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
schedule - Variable in class org.springframework.integration.scheduling.Subscription
 
SCHEDULE_ELEMENT - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
scheduleDispatcherTask(Schedule) - Method in class org.springframework.integration.bus.SubscriptionManager
 
scheduler - Variable in class org.springframework.integration.bus.SubscriptionManager
 
secondaryChannel - Variable in class org.springframework.integration.channel.interceptor.WireTap
 
selector - Variable in class org.springframework.integration.channel.ChannelPurger
 
selector - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
selector - Variable in class org.springframework.integration.transformer.MessageFilter
 
SELECTOR_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
SELECTOR_PROPERTY - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
selectors - Variable in class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
selectors - Variable in class org.springframework.integration.channel.interceptor.WireTap
 
selectors - Variable in class org.springframework.integration.message.selector.MessageSelectorChain
 
selectorsAccept(Message<?>) - Method in class org.springframework.integration.channel.interceptor.WireTap
If this wire tap has any MessageSelectors, check whether they accept the current message.
semaphore - Variable in class org.springframework.integration.channel.PriorityChannel
 
send(Message<?>) - Method in class org.springframework.integration.adapter.event.ApplicationEventTarget
 
send(Message) - Method in class org.springframework.integration.adapter.file.FileTarget
 
send(Message<?>) - Method in class org.springframework.integration.adapter.jms.JmsTarget
 
send(Message<?>) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
send(Message) - Method in class org.springframework.integration.adapter.stream.ByteStreamTarget
 
send(Message) - Method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
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.endpoint.ConcurrentTarget
 
send(Message<?>) - Method in class org.springframework.integration.endpoint.HandlerEndpoint.HandlerInvokingTarget
 
send(Message<?>) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
send(Message<?>) - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
send(Message<?>, long) - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
send(Message<?>) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
send(Object) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
send(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingTarget
 
send(Message<?>) - Method in interface org.springframework.integration.message.BlockingTarget
Send a message, blocking indefinitely if necessary.
send(Message<?>, long) - Method in interface org.springframework.integration.message.BlockingTarget
Send a message, blocking until either the message is accepted or the specified timeout period elapses.
send(Message<?>) - Method in interface org.springframework.integration.message.Target
 
SEND_PARTIAL_RESULT_ON_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
SEND_PARTIAL_RESULT_ON_TIMEOUT_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
SEND_PARTIAL_RESULTS_ON_TIMEOUT - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
SEND_TIMEOUT - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
SEND_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
SEND_TIMEOUT_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
sendAndReceive(Object) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
sendAndReceive(Object, boolean) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
sendAndReceiveWithReplyMessageCorrelator(Message<?>) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
sendAndReceiveWithTemporaryChannel(Message<?>) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
sendMailMessage(MailMessage) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
sendMesage(Message<?>, MessageChannel) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
sendMessage(ApplicationEvent) - Method in class org.springframework.integration.adapter.event.ApplicationEventSource
 
sendMessage(Message<?>, String) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
sendMessage(Message<?>, MessageChannel) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
sendMessage(Message<?>, String) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
sendPartialResultOnTimeout - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
sendTimeout - Variable in class org.springframework.integration.dispatcher.SimpleDispatcher
 
sendTimeout - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
sendTimeout - Variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
sendTimeout - Variable in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
sendToDiscardChannelIfAvailable(Message<?>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
sequenceNumber - Variable in class org.springframework.integration.message.MessageHeader
 
sequenceSize - Variable in class org.springframework.integration.message.MessageHeader
 
SequenceSizeCompletionStrategy - Class in org.springframework.integration.router
An implementation of CompletionStrategy that simply compares the current size of the message list to the expected 'sequenceSize' according to the first Message in the list.
SequenceSizeCompletionStrategy() - Constructor for class org.springframework.integration.router.SequenceSizeCompletionStrategy
 
SERVICE_NAME_PREFIX - Static variable in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
serviceInterface - Variable in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
serviceProxy - Variable in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
sessionAcknowledgeMode - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
sessionTransacted - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.adapter.event.ApplicationEventTarget
 
setAttachmentFilename(String) - Method in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
setAttribute(String, Object) - Method in class org.springframework.integration.message.MessageHeader
 
setAttributeIfAbsent(String, Object) - Method in class org.springframework.integration.message.MessageHeader
 
setAutoCreateChannels(boolean) - Method in class org.springframework.integration.bus.MessageBus
Set whether the bus should automatically create a channel when a subscription contains the name of a previously unregistered channel.
setAutoStartup(boolean) - Method in class org.springframework.integration.bus.MessageBus
Set whether to automatically start the bus after initialization.
setBcc(String[]) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the name of this channel to its bean name.
setBeanName(String) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setBeanReferenceIfAttributeDefined(RootBeanDefinition, String, Element, String) - Static method in class org.springframework.integration.config.IntegrationNamespaceUtils
Populates the property given by propertyName on the given bean definition to a reference to a bean identified by the value of the attribute specified by attributeName, if that attribute is defined in the element
setByteArrayMessageMapper(MessageMapper<byte[], MailMessage>) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
setBytesPerMessage(int) - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
setCapacity(int) - Method in class org.springframework.integration.channel.factory.PriorityChannelFactory
 
setCc(String[]) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setChannel(MessageChannel) - Method in class org.springframework.integration.channel.ChannelPublisher
 
setChannelFactory(ChannelFactory) - Method in class org.springframework.integration.bus.MessageBus
Set the ChannelFactory to use for auto-creating channels.
setChannelMappings(Map<Class<?>, MessageChannel>) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
setChannelMappings(Map<Class<? extends Throwable>, MessageChannel>) - Method in class org.springframework.integration.router.RootCauseErrorMessageRouter
 
setChannelNameAttribute(String) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
setChannelNameAttribute(String) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setChannelNameResolver(MultiChannelNameResolver) - Method in class org.springframework.integration.router.MultiChannelRouter
 
setChannelNameResolver(ChannelNameResolver) - Method in class org.springframework.integration.router.SingleChannelRouter
 
setChannelNames(String[]) - Method in class org.springframework.integration.router.RecipientListRouter
 
setChannelRegistry(ChannelRegistry) - Method in interface org.springframework.integration.channel.ChannelRegistryAware
 
setChannelRegistry(ChannelRegistry) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
setChannelRegistry(ChannelRegistry) - Method in class org.springframework.integration.endpoint.TargetEndpoint
Set the channel registry to use for looking up channels by name.
setChannelRegistry(ChannelRegistry) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
setChannelRegistry(ChannelRegistry) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
setChannelRegistry(ChannelRegistry) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
setChannelResolver(MultiChannelResolver) - Method in class org.springframework.integration.router.MultiChannelRouter
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.router.SingleChannelRouter
 
setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
 
setColdDrinkDelay(long) - Method in class org.springframework.integration.samples.cafe.Barista
 
setComparator(Comparator<Message<?>>) - Method in class org.springframework.integration.channel.factory.PriorityChannelFactory
 
setCompletionStrategy(CompletionStrategy) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Strategy to determine whether the group of messages is complete.
setConcurrencyPolicy(ConcurrencyPolicy) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
setConfigureAsyncEventMulticaster(boolean) - Method in class org.springframework.integration.bus.MessageBus
Set whether the bus should configure its asynchronous task executor to also be used by the ApplicationContext's 'applicationEventMulticaster'.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setContainer(AbstractMessageListenerContainer) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setCoreSize(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setCorrelationId(Object) - Method in class org.springframework.integration.message.MessageHeader
 
setCustomHandlerCreators(Map<Class<? extends Annotation>, MessageHandlerCreator>) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.router.RootCauseErrorMessageRouter
 
setDefaultConcurrencyPolicy(ConcurrencyPolicy) - Method in class org.springframework.integration.bus.MessageBus
Specify the default concurrency policy to be used for any endpoint that is registered without an explicitly provided policy of its own.
setDefaultReplyChannel(MessageChannel) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Set the default channel for sending aggregated Messages.
setDefaultSchedule(Schedule) - Method in class org.springframework.integration.bus.SubscriptionManager
 
setDefaultTimeout(long) - Method in class org.springframework.integration.handler.ReplyMessageCorrelator
 
setDestination(Destination) - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
setDestination(Destination) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setDestinationName(String) - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
setDestinationName(String) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Specify a channel for sending Messages that arrive after their aggregation group has either completed or timed-out.
setDispatchAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
setEndpointRegistry(EndpointRegistry) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.bus.MessageBus
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.ConcurrentTarget
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
setErrorHandler(ErrorHandler) - Method in interface org.springframework.integration.scheduling.MessagingTaskScheduler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setEventTypes(List<Class<? extends ApplicationEvent>>) - Method in class org.springframework.integration.adapter.event.ApplicationEventSource
Set the list of event types (classes that extend ApplicationEvent) that this adapter should send to the message channel.
setExpectReply(boolean) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setExpectReply(boolean) - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
Specify whether the handle method should be expected to return a reply.
setExpiration(Date) - Method in class org.springframework.integration.message.MessageHeader
Set the expiration date for this message or null to indicate 'never expire'.
setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
setFileFilter(FileFilter) - Method in class org.springframework.integration.adapter.file.FileSource
 
setFilenameFilter(FilenameFilter) - Method in class org.springframework.integration.adapter.file.FileSource
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
setFixedRate(boolean) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setFrom(String) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setHeaderGenerator(MailHeaderGenerator) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
setHeaderMapper(MessageHeaderMapper<Message>) - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
setHost(String) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setHotDrinkDelay(long) - Method in class org.springframework.integration.samples.cafe.Barista
 
setInitialDelay(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.bus.DefaultChannelFactoryBean
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setJmsTemplate(JmsTemplate) - Method in class org.springframework.integration.adapter.jms.AbstractJmsTemplateBasedAdapter
 
setKeepAliveSeconds(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setLocalWorkingDirectory(File) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the maximum number of messages for each retrieval attempt.
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
setMaxSize(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setMessageBus(MessageBus) - Method in interface org.springframework.integration.bus.MessageBusAware
 
setMessageBus(MessageBus) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setMessageBus(MessageBus) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setMessageCreator(MessageCreator<File, ?>) - Method in class org.springframework.integration.adapter.file.FileSource
 
setMessageCreator(MessageCreator) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Specify the MessageCreator to use when creating a message from the return value Object.
setMessageCreator(MessageCreator<?, ?>) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
setMessageCreator(MessageCreator) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
setMessageMapper(MessageMapper<?, ?>) - Method in class org.springframework.integration.gateway.SimpleMessagingGateway
 
setMessageMapper(MessageMapper) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMessageSelector(MessageSelector) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
setMethod(Method) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMethod(String) - Method in class org.springframework.integration.message.MethodInvokingSource
 
setMethod(Method) - Method in class org.springframework.integration.router.MessageListMethodAdapter
 
setMethodExpectsMessage(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMethodName(String) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMethodValidator(MethodValidator) - Method in class org.springframework.integration.util.NameResolvingMethodInvoker
 
setMultipartMode(int) - Method in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
setName(String) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the name of this channel.
setName(String) - Method in interface org.springframework.integration.channel.MessageChannel
Set the name of this channel.
setName(String) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setName(String) - Method in class org.springframework.integration.gateway.RequestReplyTemplate.ReplyHandlingChannelAdapter
 
setObject(Object) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setObject(Object) - Method in class org.springframework.integration.message.MethodInvokingSource
 
setObjectMessageMapper(MessageMapper<Object, MailMessage>) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
setOrderChannel(MessageChannel) - Method in class org.springframework.integration.samples.cafe.Cafe
 
setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
Set the name of the channel to which this endpoint should send reply messages.
setPassword(String) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setPeriod(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
Set the polling period.
setPort(int) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setPriority(MessagePriority) - Method in class org.springframework.integration.message.MessageHeader
 
setProperty(String, String) - Method in class org.springframework.integration.message.MessageHeader
 
setPublisherAnnotationType(Class<? extends Annotation>) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
setQueueCapacity(int) - Method in class org.springframework.integration.channel.factory.QueueChannelFactory
Sets the queue capacity for the newly created channels.
setQueueCapacity(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setReaperInterval(long) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Set the interval in milliseconds for the reaper thread.
setReceiveTimeout(long) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the maximum amount of time in milliseconds to wait for a message to be available.
setRegistryHost(String) - Method in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
setRegistryPort(int) - Method in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
setRejectionLimit(int) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the maximum number of retries upon rejection.
setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.adapter.rmi.RmiSourceAdapter
 
setRemoteWorkingDirectory(String) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Set the reply channel.
setReplyHandler(ReplyHandler) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
setReplyTimeout(long) - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
setReplyTimeout(long) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
Set the timeout in milliseconds to be enforced when this endpoint sends a reply message.
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Set the timeout value for receiving reply messages.
setReplyTo(String) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setRequestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Set the request channel.
setRequestTimeout(long) - Method in class org.springframework.integration.adapter.MessageHandlingSourceAdapter
 
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.RequestReplyTemplate
Set the timeout value for sending request messages.
setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
Set whether this router should always be required to resolve at least one channel.
setRetryInterval(long) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the amount of time in milliseconds to wait between rejections.
setReturnAddress(Object) - Method in class org.springframework.integration.message.MessageHeader
 
setReturnAddressOverrides(boolean) - Method in class org.springframework.integration.endpoint.HandlerEndpoint
 
setScheduledExecutorService(ScheduledExecutorService) - Method in class org.springframework.integration.bus.MessageBus
Set the ScheduledExecutorService to use for scheduling message dispatchers.
setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.message.selector.MessageSelectorChain
Initialize the selector chain.
setSendPartialResultOnTimeout(boolean) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Specify whether to aggregate and send the resulting Message when the timeout elapses prior to the CompletionStrategy.
setSendTimeout(long) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
setSendTimeout(long) - Method in class org.springframework.integration.dispatcher.SimpleDispatcher
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
setSendTimeout(long) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Set the timeout for sending aggregation results and discarded Messages.
setSendTimeout(long) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
setSequenceNumber(int) - Method in class org.springframework.integration.message.MessageHeader
 
setSequenceSize(int) - Method in class org.springframework.integration.message.MessageHeader
 
setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setSessionTransacted(boolean) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
setShouldFailOnRejectionLimit(boolean) - Method in class org.springframework.integration.channel.DispatcherPolicy
Specify whether an exception should be thrown when this dispatcher's DispatcherPolicy.rejectionLimit is reached.
setShouldRepeat(boolean) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
setShouldTruncate(boolean) - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
setSubject(String) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setSubscriberAnnotationType(Class<? extends Annotation>) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setSubscription(Subscription) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
setTarget(Target) - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
setTaskAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.SourceEndpoint
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
setTextBased(boolean) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setTextMessageMapper(MessageMapper<String, MailMessage>) - Method in class org.springframework.integration.adapter.mail.MailTarget
 
setTimeout(long) - Method in class org.springframework.integration.channel.ChannelPublisher
 
setTimeout(long) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
Set the timeout for sending a message to the resolved channel.
setTimeout(long) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Maximum time to wait (in milliseconds) for the completion strategy to become true.
setTimeUnit(TimeUnit) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setTo(String[]) - Method in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
setTrackedCorrelationIdCapacity(int) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Set the number of completed correlationIds to track.
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.util.DefaultMethodInvoker
 
setupDirectories() - Static method in class org.springframework.integration.samples.filecopy.FileCopyDemoCommon
 
setUsername(String) - Method in class org.springframework.integration.adapter.ftp.FtpSource
 
setValueIfAttributeDefined(RootBeanDefinition, String, Element, String) - Static method in class org.springframework.integration.config.IntegrationNamespaceUtils
Populates the property identified by propertyName on the bean definition to the value of the attribute specified by attributeName, if that attribute is defined in the element
shots - Variable in class org.springframework.integration.samples.cafe.Drink
 
shouldAppendNewLine - Variable in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
shouldFailOnRejectionLimit - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerTargetAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.jms.config.JmsGatewayParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.jms.config.JmsSourceParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.jms.config.JmsTargetParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.mail.config.MailTargetParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.rmi.config.RmiTargetAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.stream.config.ConsoleSourceParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.stream.config.ConsoleTargetParser
 
shouldGenerateId() - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
shouldGenerateId() - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.config.SourceEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.httpinvoker.config.HttpInvokerTargetAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.jms.config.JmsGatewayParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.jms.config.JmsSourceParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.jms.config.JmsTargetParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.mail.config.MailTargetParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.rmi.config.RmiTargetAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.stream.config.ConsoleSourceParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.stream.config.ConsoleTargetParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.channel.config.AbstractChannelParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.AbstractTargetEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.SourceEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
shouldRepeat - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
shouldTruncate - Variable in class org.springframework.integration.adapter.stream.ByteStreamSource
 
SimpleDispatcher - Class in org.springframework.integration.dispatcher
Basic implementation of MessageDispatcher.
SimpleDispatcher(DispatcherPolicy) - Constructor for class org.springframework.integration.dispatcher.SimpleDispatcher
 
SimpleFileMessageMapper - Class in org.springframework.integration.adapter.file
A default MessageMapper for FileTarget, converting payloads of the File, byte[] and String types to files.
SimpleFileMessageMapper(String) - Constructor for class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
SimpleFileMessageMapper(File) - Constructor for class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 
SimpleMessageStore - Class in org.springframework.integration.message
Map-based implementation of MessageStore that enforces capacity.
SimpleMessageStore(int) - Constructor for class org.springframework.integration.message.SimpleMessageStore
 
SimpleMessagingGateway - Class in org.springframework.integration.gateway
A general purpose class that supports a variety of message exchanges.
SimpleMessagingGateway(MessageChannel) - Constructor for class org.springframework.integration.gateway.SimpleMessagingGateway
 
SimpleMessagingGateway() - Constructor for class org.springframework.integration.gateway.SimpleMessagingGateway
 
SimpleMessagingTaskScheduler - Class in org.springframework.integration.scheduling
An implementation of MessagingTaskScheduler that understands PollingSchedules.
SimpleMessagingTaskScheduler(ScheduledExecutorService) - Constructor for class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
SimpleMessagingTaskScheduler.MessagingTaskRunner - Class in org.springframework.integration.scheduling
 
SimpleMessagingTaskScheduler.MessagingTaskRunner(Runnable) - Constructor for class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
SimpleWebServiceTargetAdapter - Class in org.springframework.integration.ws.adapter
A target channel adapter for calling out to a Web Service.
SimpleWebServiceTargetAdapter(URI) - Constructor for class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter
 
SimpleWebServiceTargetAdapter(URI, SourceExtractor) - Constructor for class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter
 
SimpleWebServiceTargetAdapter.DefaultSourceExtractor - Class in org.springframework.integration.ws.adapter
 
SimpleWebServiceTargetAdapter.DefaultSourceExtractor() - Constructor for class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter.DefaultSourceExtractor
 
SingleChannelRouter - Class in org.springframework.integration.router
A router implementation for sending to at most one MessageChannel.
SingleChannelRouter() - Constructor for class org.springframework.integration.router.SingleChannelRouter
 
size - Variable in class org.springframework.integration.adapter.ftp.FileInfo
 
size() - Method in interface org.springframework.integration.message.MessageStore
 
size() - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
size() - Method in class org.springframework.integration.message.SimpleMessageStore
 
SOAP_ACTION_PROPERTY_KEY - Static variable in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
source - Variable in class org.springframework.integration.dispatcher.DefaultPollingDispatcher
 
source - Variable in class org.springframework.integration.dispatcher.DirectChannel
 
Source<T> - Interface in org.springframework.integration.message
Base interface for any source of Messages.
SourceEndpoint - Class in org.springframework.integration.endpoint
A channel adapter that retrieves messages from a Source and then sends the resulting messages to the provided MessageChannel.
SourceEndpoint(Source<?>, MessageChannel, Schedule) - Constructor for class org.springframework.integration.endpoint.SourceEndpoint
 
SourceEndpoint.MethodNameAdvisor - Class in org.springframework.integration.endpoint
 
SourceEndpoint.MethodNameAdvisor(Advice, String) - Constructor for class org.springframework.integration.endpoint.SourceEndpoint.MethodNameAdvisor
 
SourceEndpointParser - Class in org.springframework.integration.config
Parser for the element.
SourceEndpointParser() - Constructor for class org.springframework.integration.config.SourceEndpointParser
 
sourceExtractor - Variable in class org.springframework.integration.ws.adapter.SimpleWebServiceTargetAdapter
 
split(DrinkOrder) - Method in class org.springframework.integration.samples.cafe.OrderSplitter
 
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.
SplitterMessageHandlerAdapter - Class in org.springframework.integration.router
MessageHandler adapter for methods annotated with @Splitter.
SplitterMessageHandlerAdapter(Object, Method, String) - Constructor for class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
SplitterMessageHandlerAdapter(Object, String, String) - Constructor for class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
SplitterMessageHandlerCreator - Class in org.springframework.integration.router.config
Creates a MessageHandler adapter for splitter methods.
SplitterMessageHandlerCreator() - Constructor for class org.springframework.integration.router.config.SplitterMessageHandlerCreator
 
SplitterParser - Class in org.springframework.integration.router.config
Parser for the <splitter/> element.
SplitterParser() - Constructor for class org.springframework.integration.router.config.SplitterParser
 
start() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
start() - Method in class org.springframework.integration.bus.MessageBus
 
start() - Method in class org.springframework.integration.bus.SubscriptionManager
 
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.endpoint.TargetEndpoint
 
start() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
starting - Variable in class org.springframework.integration.bus.MessageBus
 
StaticMailHeaderGenerator - Class in org.springframework.integration.adapter.mail
Mail header generator implementation that populates a mail message header from statically configured properties.
StaticMailHeaderGenerator() - Constructor for class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
stderr() - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
Factory method that creates a target for stderr (System.err) with the default charset encoding.
stderr(String) - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
Factory method that creates a target for stderr (System.err) with the specified charset encoding.
stdin() - Static method in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
stdin(String) - Static method in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
stdout() - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
Factory method that creates a target for stdout (System.out) with the default charset encoding.
stdout(String) - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTarget
Factory method that creates a target for stdout (System.out) with the specified charset encoding.
stop() - Method in class org.springframework.integration.adapter.jms.JmsGateway
 
stop() - Method in class org.springframework.integration.bus.MessageBus
 
stop() - Method in class org.springframework.integration.bus.SubscriptionManager
 
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.endpoint.TargetEndpoint
 
stop() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
stream - Variable in class org.springframework.integration.adapter.stream.ByteStreamSource
 
stream - Variable in class org.springframework.integration.adapter.stream.ByteStreamTarget
 
streamMonitor - Variable in class org.springframework.integration.adapter.stream.ByteStreamSource
 
StringMessage - Class in org.springframework.integration.message
A message implementation that accepts a String payload.
StringMessage(String) - Constructor for class org.springframework.integration.message.StringMessage
 
StringMessage(Object, String) - Constructor for class org.springframework.integration.message.StringMessage
 
SUBJECT - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
subject - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
Subscribable - Interface in org.springframework.integration.message
Interface for any component that accepts subscribers.
subscribe(Target) - Method in class org.springframework.integration.dispatcher.DirectChannel
 
subscribe(Target) - Method in class org.springframework.integration.dispatcher.SimpleDispatcher
 
subscribe(Target) - Method in interface org.springframework.integration.message.Subscribable
Register a Target as a subscriber to this source.
Subscriber - Annotation Type in org.springframework.integration.annotation
Indicates that a method-invoking handler adapter should delegate to this method.
SUBSCRIBER_ANNOTATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.config.AnnotationDrivenParser
 
SubscriberAnnotationPostProcessor - Class in org.springframework.integration.config
A BeanPostProcessor that creates a method-invoking handler adapter when it discovers methods annotated with @Subscriber.
SubscriberAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
subscriberAnnotationType - Variable in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
subscription - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
Subscription - Class in org.springframework.integration.scheduling
Configuration metadata for activating a subscription.
Subscription(MessageChannel) - Constructor for class org.springframework.integration.scheduling.Subscription
 
Subscription(String) - Constructor for class org.springframework.integration.scheduling.Subscription
 
Subscription(MessageChannel, Schedule) - Constructor for class org.springframework.integration.scheduling.Subscription
 
Subscription(String, Schedule) - Constructor for class org.springframework.integration.scheduling.Subscription
 
SUBSCRIPTION_PROPERTY - Static variable in class org.springframework.integration.config.AbstractTargetEndpointParser
 
SubscriptionManager - Class in org.springframework.integration.bus
Manages subscriptions for Targets to a MessageChannel including the creation, scheduling, and lifecycle management of dispatchers.
SubscriptionManager(MessageChannel, MessagingTaskScheduler) - Constructor for class org.springframework.integration.bus.SubscriptionManager
 
subscriptionManagers - Variable in class org.springframework.integration.bus.MessageBus
 
SUPPORTED_PROPERTY_TYPES - Static variable in class org.springframework.integration.adapter.jms.DefaultJmsHeaderMapper
 

T

target - Variable in class org.springframework.integration.endpoint.ConcurrentTarget
 
target - Variable in class org.springframework.integration.endpoint.TargetEndpoint
 
target - Variable in class org.springframework.integration.handler.InterceptingMessageHandler
 
Target - Interface in org.springframework.integration.message
Interface for any target to which Messages can be sent.
TargetEndpoint - Class in org.springframework.integration.endpoint
Base class for MessageEndpoint implementations to which Messages may be sent.
TargetEndpoint() - Constructor for class org.springframework.integration.endpoint.TargetEndpoint
 
TargetEndpoint(Target) - Constructor for class org.springframework.integration.endpoint.TargetEndpoint
 
TargetEndpointParser - Class in org.springframework.integration.config
Parser for the <target-endpoint> element.
TargetEndpointParser() - Constructor for class org.springframework.integration.config.TargetEndpointParser
 
targetMessageStore - Variable in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
targets - Variable in class org.springframework.integration.dispatcher.SimpleDispatcher
 
task - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
task - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
taskAdviceChain - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
taskExecutor - Variable in class org.springframework.integration.adapter.jms.JmsGateway
 
taskInitialized - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
taskMonitor - Variable in class org.springframework.integration.endpoint.SourceEndpoint
 
taskScheduler - Variable in class org.springframework.integration.bus.MessageBus
 
TestMessage - Class in org.springframework.integration.test
 
TestMessage(String) - Constructor for class org.springframework.integration.test.TestMessage
 
TEXT_SOURCE_TYPE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
textBased - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 
TextFileCopyDemo - Class in org.springframework.integration.samples.filecopy
Demo of file source and target adapters.
TextFileCopyDemo() - Constructor for class org.springframework.integration.samples.filecopy.TextFileCopyDemo
 
TextFileMessageCreator - Class in org.springframework.integration.adapter.file
A MessageCreator implementation for creating messages with a String payload from a File.
TextFileMessageCreator() - Constructor for class org.springframework.integration.adapter.file.TextFileMessageCreator
 
TextMailMessageMapper - Class in org.springframework.integration.adapter.mail
Message mapper for transforming integration messages with a String payload into simple text e-mail messages.
TextMailMessageMapper() - Constructor for class org.springframework.integration.adapter.mail.TextMailMessageMapper
 
textMessageMapper - Variable in class org.springframework.integration.adapter.mail.MailTarget
 
ThreadLocalChannel - Class in org.springframework.integration.channel
A channel implementation that stores messages in a thread-bound queue.
ThreadLocalChannel() - Constructor for class org.springframework.integration.channel.ThreadLocalChannel
 
ThreadLocalChannel.ThreadLocalMessageHolder - Class in org.springframework.integration.channel
 
ThreadLocalChannel.ThreadLocalMessageHolder() - Constructor for class org.springframework.integration.channel.ThreadLocalChannel.ThreadLocalMessageHolder
 
ThreadLocalChannelFactory - Class in org.springframework.integration.channel.factory
A ChannelFactory implementation for creating ThreadLocalChannel instances.
ThreadLocalChannelFactory() - Constructor for class org.springframework.integration.channel.factory.ThreadLocalChannelFactory
 
ThreadLocalChannelParser - Class in org.springframework.integration.channel.config
Parser for the <thread-local-channel> element.
ThreadLocalChannelParser() - Constructor for class org.springframework.integration.channel.config.ThreadLocalChannelParser
 
ticker - Variable in class org.springframework.integration.samples.quote.Quote
 
timeout - Variable in class org.springframework.integration.channel.ChannelPublisher
 
TIMEOUT - Static variable in class org.springframework.integration.config.AggregatorParser
 
timeout - Variable in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
timeout - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
TIMEOUT - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
timestamp - Variable in class org.springframework.integration.message.MessageHeader
 
timestamp - Variable in class org.springframework.integration.router.AggregationBarrier
 
timeUnit - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
TO - Static variable in class org.springframework.integration.adapter.mail.MailAttributeKeys
 
to - Variable in class org.springframework.integration.adapter.mail.StaticMailHeaderGenerator
 
toMessage(Object, Session) - Method in class org.springframework.integration.adapter.jms.HeaderMappingMessageConverter
 
toMessage(MailMessage) - Method in class org.springframework.integration.adapter.mail.ByteArrayMailMessageMapper
 
toMessage(MailMessage) - Method in class org.springframework.integration.adapter.mail.MailTarget.DefaultObjectMailMessageMapper
 
toMessage(MailMessage) - Method in class org.springframework.integration.adapter.mail.TextMailMessageMapper
 
toString() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
toString() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
toString() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
toString() - Method in class org.springframework.integration.message.GenericMessage
 
toString() - Method in class org.springframework.integration.message.MessageHeader
 
toString() - Method in class org.springframework.integration.samples.cafe.Drink
 
toString() - Method in class org.springframework.integration.samples.quote.Quote
 
toString() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
TRACKED_CORRELATION_ID_CAPACITY - Static variable in class org.springframework.integration.router.config.AggregatorMessageHandlerCreator
 
TRACKED_CORRELATION_ID_CAPACITY_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
TRACKED_CORRELATION_ID_CAPACITY_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
trackedCorrelationIdCapacity - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
trackedCorrelationIds - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
TYPE - Static variable in class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
type - Variable in class org.springframework.integration.handler.annotation.AnnotationMethodMessageMapper.MethodParameterMetadata
 
type - Variable in class org.springframework.integration.samples.cafe.Drink
 
TYPE_ATTRIBUTE - Static variable in class org.springframework.integration.adapter.file.config.FileSourceParser
 
typeConverter - Variable in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
typeConverter - Variable in class org.springframework.integration.util.DefaultMethodInvoker
 

U

UnexpiredMessageSelector - Class in org.springframework.integration.message.selector
A MessageSelector that accepts Messages that are not expired.
UnexpiredMessageSelector() - Constructor for class org.springframework.integration.message.selector.UnexpiredMessageSelector
 
unregisterChannel(String) - Method in class org.springframework.integration.bus.MessageBus
 
unregisterChannel(String) - Method in interface org.springframework.integration.channel.ChannelRegistry
 
unregisterChannel(String) - Method in class org.springframework.integration.channel.DefaultChannelRegistry
 
unregisterEndpoint(String) - Method in class org.springframework.integration.bus.MessageBus
 
unregisterEndpoint(String) - Method in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
unregisterEndpoint(String) - Method in interface org.springframework.integration.endpoint.EndpointRegistry
 
unsubscribe(Target) - Method in class org.springframework.integration.dispatcher.DirectChannel
 
unsubscribe(Target) - Method in class org.springframework.integration.dispatcher.SimpleDispatcher
 
unsubscribe(Target) - Method in interface org.springframework.integration.message.Subscribable
Remove a Target from the subscribers of this source.
USER_DEFINED_ATTRIBUTE_PREFIX - Static variable in class org.springframework.integration.adapter.jms.JmsAttributeKeys
 
username - Variable in class org.springframework.integration.adapter.ftp.FtpSource
 

V

validate(Method) - Method in class org.springframework.integration.message.MethodInvokingSource.MessageReceivingMethodValidator
 
validate() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
validate() - Method in class org.springframework.integration.router.MultiChannelRouter
 
validate() - Method in class org.springframework.integration.router.SingleChannelRouter
 
validate(Method) - Method in interface org.springframework.integration.util.MethodValidator
 
valueOf(String) - Static method in enum org.springframework.integration.message.MessagePriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.samples.cafe.DrinkType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.integration.message.MessagePriority
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.springframework.integration.samples.cafe.DrinkType
Returns an array containing the constants of this enum type, in the order they're declared.
verifySerializability(Message<?>) - Method in class org.springframework.integration.adapter.AbstractRemotingTargetAdapter
 

W

waitForMessage(Object, long, boolean) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
WebServiceDemo - Class in org.springframework.integration.samples.ws
Demonstrating a web service invocation through a Web Service Target.
WebServiceDemo() - Constructor for class org.springframework.integration.samples.ws.WebServiceDemo
 
WebServiceTargetAdapterParser - Class in org.springframework.integration.ws.config
Parser for the <ws-target/> element.
WebServiceTargetAdapterParser() - Constructor for class org.springframework.integration.ws.config.WebServiceTargetAdapterParser
 
webServiceTemplate - Variable in class org.springframework.integration.ws.adapter.AbstractWebServiceTargetAdapter
 
WireTap - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that publishes a copy of the intercepted message to a secondary channel 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 MessageSelectors.
WireTap(MessageChannel, List<MessageSelector>) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with MessageSelectors.
writer - Variable in class org.springframework.integration.adapter.stream.CharacterStreamTarget
 
writeToFile(File, Object) - Method in class org.springframework.integration.adapter.file.SimpleFileMessageMapper
 

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