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

A

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<T> - Class in org.springframework.integration.handler
Base implementation of the MessageHandler interface that creates an invoker for 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
 
AbstractMessageMapper<M,O> - Class in org.springframework.integration.message
Base class that provides the default IdGenerator as well as a setter for providing a custom id generator implementation.
AbstractMessageMapper() - Constructor for class org.springframework.integration.message.AbstractMessageMapper
 
AbstractMessagingTaskScheduler - Class in org.springframework.integration.scheduling
Base class for MessagingTaskScheduler implementations.
AbstractMessagingTaskScheduler() - Constructor for class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
 
AbstractRoutingMessageHandler - Class in org.springframework.integration.router
Base class for message router implementations.
AbstractRoutingMessageHandler() - Constructor for class org.springframework.integration.router.AbstractRoutingMessageHandler
 
AbstractSourceAdapter<T> - Class in org.springframework.integration.adapter
A base class providing common behavior for source adapters.
AbstractSourceAdapter() - Constructor for class org.springframework.integration.adapter.AbstractSourceAdapter
 
AbstractTargetAdapter<T> - Class in org.springframework.integration.adapter
Base class providing common behavior for target adapters.
AbstractTargetAdapter() - Constructor for class org.springframework.integration.adapter.AbstractTargetAdapter
 
accept(Message<?>) - Method in interface org.springframework.integration.message.selector.MessageSelector
 
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
 
activateEndpoint(MessageEndpoint) - Method in class org.springframework.integration.bus.MessageBus
 
activateEndpoints() - 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.
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
 
addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
addHandler(MessageHandler, Schedule) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDistributor
 
addHandler(MessageHandler, Schedule) - Method in interface org.springframework.integration.dispatcher.SchedulingMessageDispatcher
 
addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.SynchronousChannel
 
addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Add a channel interceptor to the end of the list.
addMessageSelector(MessageSelector) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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.AbstractSourceAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.MethodInvokingSource
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
afterPropertiesSet() - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
afterPropertiesSet() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
afterPropertiesSet() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
afterPropertiesSet() - Method in class org.springframework.integration.router.AggregatingMessageHandler
Initialize this handler.
aggregate(Collection<Message<?>>) - Method in interface org.springframework.integration.router.Aggregator
 
aggregate(Collection<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.
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, String) - Constructor for class org.springframework.integration.router.AggregatorAdapter
 
AggregatorAdapter(Object, Method) - 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
 
ArgumentListPreparer - Interface in org.springframework.integration.adapter
A strategy for preparing an argument list from a single source object.
argumentListPreparer - Variable in class org.springframework.integration.adapter.MethodInvokingTarget
 
ATTRIBUTE_KEY - Static variable in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
attributes - Variable in class org.springframework.integration.message.MessageHeader
 
attributes - Variable in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
attributes - Variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
autoCreateChannels - Variable in class org.springframework.integration.bus.MessageBus
 
autoStartup - Variable in class org.springframework.integration.bus.MessageBus
 

B

barriers - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
BaseBlockingQueueChannel - Class in org.springframework.integration.channel
Base implementation for message channels that delegate to a BlockingQueue.
BaseBlockingQueueChannel(BlockingQueue<Message<?>>, DispatcherPolicy) - Constructor for class org.springframework.integration.channel.BaseBlockingQueueChannel
Create a channel with the specified queue and dispatcher policy.
beanClassLoader - Variable in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
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
 

C

capacity - Variable in class org.springframework.integration.util.BoundedHashMap
 
CAPACITY_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelParser
 
channel - Variable in class org.springframework.integration.adapter.AbstractSourceAdapter
 
channel - Variable in class org.springframework.integration.dispatcher.ChannelPollingMessageRetriever
 
channel - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
channel - Variable in class org.springframework.integration.scheduling.Subscription
 
CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelAdapterParser
 
CHANNEL_KEY - Static variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
ChannelAdapterParser - Class in org.springframework.integration.config
Parser for inbound and outbound channel adapters.
ChannelAdapterParser(boolean) - Constructor for class org.springframework.integration.config.ChannelAdapterParser
 
channelAttributeName - Variable in class org.springframework.integration.aop.AnnotationAwareMessagePublishingInterceptor
 
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
 
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
 
ChannelParser - Class in org.springframework.integration.config
Parser for the channel element of the integration namespace.
ChannelParser() - Constructor for class org.springframework.integration.config.ChannelParser
 
ChannelPollingMessageRetriever - Class in org.springframework.integration.dispatcher
Message retriever that polls a MessageChannel.
ChannelPollingMessageRetriever(MessageChannel) - Constructor for class org.springframework.integration.dispatcher.ChannelPollingMessageRetriever
 
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.DefaultMessageEndpoint
 
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
 
clear() - Method in class org.springframework.integration.channel.BaseBlockingQueueChannel
 
clear() - Method in interface org.springframework.integration.channel.MessageChannel
Remove all Messages from this channel.
clear() - Method in class org.springframework.integration.dispatcher.SynchronousChannel
Remove and return any messages that are stored for the current thread.
COMPARATOR_REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelParser
 
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_PROPERTY - Static variable in class org.springframework.integration.config.AggregatorParser
 
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.
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.EndpointParser
 
CONCURRENCY_POLICY_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
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.DefaultMessageEndpoint
 
ConcurrentHandler - Class in org.springframework.integration.endpoint
A MessageHandler implementation that encapsulates a ThreadPoolTaskExecutor and delegates to a wrapped handler for concurrent, asynchronous message handling.
ConcurrentHandler(MessageHandler, ExecutorService) - Constructor for class org.springframework.integration.endpoint.ConcurrentHandler
 
ConcurrentHandler.HandlerTask - Class in org.springframework.integration.endpoint
 
ConcurrentHandler.HandlerTask(Message<?>) - Constructor for class org.springframework.integration.endpoint.ConcurrentHandler.HandlerTask
 
configureDefaultOutput(Object, String, MessageEndpoint, DefaultMessageEndpoint) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
configureDispatcherPolicy(Element, DispatcherPolicy) - Method in class org.springframework.integration.config.ChannelParser
 
configureInput(Object, String, MessageEndpoint, DefaultMessageEndpoint) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
copyHeader(MessageHeader) - Method in class org.springframework.integration.message.GenericMessage
 
CORE_SIZE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
coreSize - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
correlationId - Variable in class org.springframework.integration.message.MessageHeader
 
createAdvisor() - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
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) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
createMessageEndpointPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
createPublisherPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 
createReplyMessage(Object, MessageHeader) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
createSubscriberPostProcessor(ParserContext) - Method in class org.springframework.integration.config.AnnotationDrivenParser
 

D

DATATYPE_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelParser
 
DEFAULT_CAPACITY - Static variable in interface org.springframework.integration.channel.MessageChannel
 
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_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_OUTPUT_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
DEFAULT_OUTPUT_CHANNEL_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
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_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
 
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.dispatcher.SynchronousChannel
 
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
 
defaultIdGenerator - Variable in class org.springframework.integration.message.GenericMessage
 
DefaultMessageDispatcher - Class in org.springframework.integration.dispatcher
Default implementation of MessageDispatcher.
DefaultMessageDispatcher(MessageChannel, MessagingTaskScheduler) - Constructor for class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
DefaultMessageDispatcher.DispatcherTask - Class in org.springframework.integration.dispatcher
 
DefaultMessageDispatcher.DispatcherTask(Schedule) - Constructor for class org.springframework.integration.dispatcher.DefaultMessageDispatcher.DispatcherTask
 
DefaultMessageDistributor - Class in org.springframework.integration.dispatcher
Default implementation of the MessageDistributor interface.
DefaultMessageDistributor(DispatcherPolicy) - Constructor for class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
DefaultMessageEndpoint - Class in org.springframework.integration.endpoint
Default implementation of the MessageEndpoint interface.
DefaultMessageEndpoint() - Constructor for class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
DefaultMessageEndpoint(MessageHandler) - Constructor for class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
DefaultMessageEndpoint.EndpointReplyHandler - Class in org.springframework.integration.endpoint
 
DefaultMessageEndpoint.EndpointReplyHandler() - Constructor for class org.springframework.integration.endpoint.DefaultMessageEndpoint.EndpointReplyHandler
 
DefaultMessageHandlerAdapter<T> - Class in org.springframework.integration.handler
An implementation of MessageHandler that invokes the specified method on the provided 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
 
DefaultOutput - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of sending messages.
defaultOutputChannelName - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
defaultReceiveTimeout - Variable in class org.springframework.integration.channel.RequestReplyTemplate
 
defaultReplyChannel - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
defaultSchedule - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
defaultSendTimeout - Variable in class org.springframework.integration.channel.RequestReplyTemplate
 
DefaultTargetAdapter<T> - Class in org.springframework.integration.adapter
Target adapter implementation that delegates to a MessageMapper and then passes the resulting object to the provided Target.
DefaultTargetAdapter(Target<T>) - Constructor for class org.springframework.integration.adapter.DefaultTargetAdapter
 
defaultTimeout - Variable in class org.springframework.integration.handler.ResponseCorrelator
 
destroy() - Method in class org.springframework.integration.endpoint.ConcurrentHandler
 
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() - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
dispatch() - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
DISPATCHER_POLICY_ELEMENT - Static variable in class org.springframework.integration.config.ChannelParser
 
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.DefaultMessageDistributor
 
dispatchers - Variable in class org.springframework.integration.bus.MessageBus
 
distribute(Message<?>) - Method in class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
distribute(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDistributor
 
distributor - Variable in class org.springframework.integration.dispatcher.SynchronousChannel
 
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
 
doDispatch(MessageDistributor) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
doHandle(Message<?>, SimpleMethodInvoker<T>) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
Subclasses must implement this method.
doHandle(Message, SimpleMethodInvoker) - Method in class org.springframework.integration.handler.DefaultMessageHandlerAdapter
 
doHandle(Message, SimpleMethodInvoker) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
doHandle(Message<?>, SimpleMethodInvoker<T>) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
doReceive(long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Subclasses must implement this method.
doReceive(long) - Method in class org.springframework.integration.channel.BaseBlockingQueueChannel
 
doReceive(long) - Method in class org.springframework.integration.channel.PriorityChannel
 
doReceive(long) - Method in class org.springframework.integration.dispatcher.SynchronousChannel
 
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.BaseBlockingQueueChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.PriorityChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.dispatcher.SynchronousChannel
 

E

EndpointParser - Class in org.springframework.integration.config
Parser for the endpoint element of the integration namespace.
EndpointParser() - Constructor for class org.springframework.integration.config.EndpointParser
 
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.
endpoints - Variable in class org.springframework.integration.endpoint.DefaultEndpointRegistry
 
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.EndpointParser
 
ERROR_HANDLER_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
errorChannel - Variable in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
errorHandler - Variable in class org.springframework.integration.endpoint.ConcurrentHandler
 
errorHandler - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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
 
execute(Runnable) - Method in class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
Submit a task to be run once.
executor - Variable in class org.springframework.integration.bus.MessageBus
 
executor - Variable in class org.springframework.integration.channel.RequestReplyTemplate
 
executor - Variable in class org.springframework.integration.endpoint.ConcurrentHandler
 
executor - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
executor - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
expectsMessage - Variable in class org.springframework.integration.handler.DefaultMessageHandlerAdapter
 
expiration - Variable in class org.springframework.integration.message.MessageHeader
 
extractPayloadsFromMessages(Collection<Message<?>>) - Method in class org.springframework.integration.router.AggregatorAdapter
 

F

failedMessage - Variable in exception org.springframework.integration.message.MessageHandlingException
 
fixedRate - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
fromMessage(Message<M>) - Method in interface org.springframework.integration.message.MessageMapper
Map from the given Message to an object.
fromMessage(Message<T>) - Method in class org.springframework.integration.message.SimplePayloadMessageMapper
Return the payload of the given Message.

G

generateId() - Method in interface org.springframework.integration.util.IdGenerator
Generate a new unique id.
generateId() - Method in class org.springframework.integration.util.RandomUuidGenerator
 
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
 
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
 
getBeanClass(Element) - Method in class org.springframework.integration.config.MessageBusParser
 
getBeanClass(Object) - Method in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
getChannel() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
getChannel() - Method in class org.springframework.integration.scheduling.Subscription
 
getChannelName() - Method in class org.springframework.integration.scheduling.Subscription
 
getChannelRegistry() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
getCollectionActualType(Method) - Static method in class org.springframework.integration.router.AggregatorAdapter
 
getConcurrencyPolicy() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
getConcurrencyPolicy() - Method in interface org.springframework.integration.endpoint.MessageEndpoint
 
getCoreSize() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getCorrelationId(Message<?>) - Method in class org.springframework.integration.handler.ResponseCorrelator
Retrieve the correlation identifier from the provided message.
getCorrelationId() - Method in class org.springframework.integration.message.MessageHeader
 
getDefaultOutputChannelName() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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
getDistributor(Schedule) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
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.MessageHandlingException
Return the failed Message if available, may be null.
getFixedRate() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getHandler() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
getHeader() - Method in class org.springframework.integration.message.GenericMessage
 
getHeader() - Method in interface org.springframework.integration.message.Message
 
getId() - Method in class org.springframework.integration.message.GenericMessage
 
getId() - Method in interface org.springframework.integration.message.Message
 
getIdGenerator() - Method in class org.springframework.integration.message.AbstractMessageMapper
 
getInitialDelay() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
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.message.RetrievalBlockingMessageStore.MessageHolder
 
getMessageMapper() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
getMessageMapper() - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
getMessages() - Method in class org.springframework.integration.router.AggregationBarrier
 
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.DefaultMessageEndpoint
 
getName() - Method in interface org.springframework.integration.endpoint.MessageEndpoint
 
getObject() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
getOrder() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
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.endpoint.ConcurrencyPolicy
 
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.
getResponse(Object) - Method in class org.springframework.integration.handler.ResponseCorrelator
 
getResponse(Object, long) - Method in class org.springframework.integration.handler.ResponseCorrelator
 
getRetryInterval() - Method in class org.springframework.integration.channel.DispatcherPolicy
Return the amount of time in milliseconds to wait between rejections.
getReturnAddress() - Method in class org.springframework.integration.message.MessageHeader
 
getSchedule() - Method in class org.springframework.integration.adapter.PollingSourceAdapter.PollingSourceAdapterTask
 
getSchedule() - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher.DispatcherTask
 
getSchedule() - Method in interface org.springframework.integration.scheduling.MessagingTask
 
getSchedule() - Method in class org.springframework.integration.scheduling.Subscription
 
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.
getSource() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
getSubscription() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
getSubscription() - Method in interface org.springframework.integration.endpoint.MessageEndpoint
 
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
 
getUndeliveredMessage() - Method in exception org.springframework.integration.message.MessageDeliveryException
Return the undelivered Message if available, may be null.

H

handle(Message) - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
handle(Message<?>) - Method in class org.springframework.integration.endpoint.ConcurrentHandler
 
handle(Message<?>, MessageHeader) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint.EndpointReplyHandler
 
handle(Message<?>) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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.ResponseCorrelator
 
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
 
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.ConcurrentHandler
 
handler - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
HANDLER_CHAIN_ELEMENT - Static variable in class org.springframework.integration.config.HandlerParser
 
HANDLER_ELEMENT - Static variable in class org.springframework.integration.config.EndpointParser
 
HANDLER_ELEMENT - Static variable in class org.springframework.integration.config.HandlerParser
 
HANDLER_METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
HANDLER_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
HANDLER_REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
handlerCount - Variable in class org.springframework.integration.dispatcher.SynchronousChannel
 
handlerCreators - Variable in class org.springframework.integration.config.MessageEndpointAnnotationPostProcessor
 
HandlerParser - Class in org.springframework.integration.config
Parser for the <handler/> element.
HandlerParser() - Constructor for class org.springframework.integration.config.HandlerParser
 
handlers - Variable in class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
handlers - Variable in class org.springframework.integration.handler.MessageHandlerChain
 
HANDLERS_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
HANDLERS_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
hasErrorHandler() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
hashCode() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
header - Variable in class org.springframework.integration.message.GenericMessage
 

I

id - Variable in class org.springframework.integration.message.GenericMessage
 
ID_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
ID_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelAdapterParser
 
ID_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelParser
 
ID_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
idGenerator - Variable in class org.springframework.integration.message.AbstractMessageMapper
 
IdGenerator - Interface in org.springframework.integration.util
A strategy for generating unique ids.
init() - Method in class org.springframework.integration.config.IntegrationNamespaceHandler
 
initialDelay - Variable in class org.springframework.integration.scheduling.PollingSchedule
 
initialize() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
Subclasses may implement this to take advantage of the initialization callback.
initialize() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
initialize() - Method in class org.springframework.integration.bus.MessageBus
 
initialize() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
Subclasses may override this method to provide additional initialization.
initialize() - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
initialized - Variable in class org.springframework.integration.adapter.AbstractSourceAdapter
 
initialized - Variable in class org.springframework.integration.bus.MessageBus
 
initialized - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
initialized - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
initialized - Variable in class org.springframework.integration.router.AggregatingMessageHandler
 
initializing - Variable in class org.springframework.integration.bus.MessageBus
 
initialValue() - Method in class org.springframework.integration.dispatcher.SynchronousChannel.ThreadLocalMessageHolder
 
INPUT_CHANNEL_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
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.config.ChannelParser
 
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.config.ChannelParser
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Invoke the target method and publish its return value.
invokeMethod(SimpleMethodInvoker<?>, Object) - Method in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
invokeMethod(Object...) - Method in class org.springframework.integration.util.SimpleMethodInvoker
 
invoker - Variable in class org.springframework.integration.adapter.MethodInvokingSource
 
invoker - Variable in class org.springframework.integration.adapter.MethodInvokingTarget
 
invoker - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
invoker - Variable in class org.springframework.integration.router.AggregatorAdapter
 
isActualTypeParametrizedMessage(Method) - Static method in class org.springframework.integration.router.AggregatorAdapter
 
isActualTypeRawMessage(Method) - Static method in class org.springframework.integration.router.AggregatorAdapter
 
isComplete(List<Message<?>>) - Method in interface org.springframework.integration.router.CompletionStrategy
 
isComplete(List<Message<?>>) - Method in class org.springframework.integration.router.SequenceSizeCompletionStrategy
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.MessageBusParser
 
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.AggregatorAdapter
 
isInbound - Variable in class org.springframework.integration.config.ChannelAdapterParser
 
isInitialized() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
isMethodParameterParametrized(Method) - Static method in class org.springframework.integration.router.AggregatorAdapter
 
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.PollingSourceAdapter
 
isRunning() - Method in class org.springframework.integration.bus.MessageBus
 
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.dispatcher.DefaultMessageDispatcher
 
isRunning() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
isRunning() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 

K

KEEP_ALIVE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
keepAliveSeconds - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 

L

lifecycleMonitor - Variable in class org.springframework.integration.bus.MessageBus
 
lifecycleMonitor - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
lifecycleMonitor - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
lifecycleMonitor - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
lifecycleSourceAdapters - Variable in class org.springframework.integration.bus.MessageBus
 
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
 
lock - Variable in class org.springframework.integration.router.AggregationBarrier
 
logger - Variable in class org.springframework.integration.adapter.AbstractSourceAdapter
 
logger - Variable in class org.springframework.integration.adapter.AbstractTargetAdapter
 
logger - Variable in class org.springframework.integration.adapter.MethodInvokingTarget
 
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.channel.AbstractMessageChannel
 
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.DefaultMessageDispatcher
 
logger - Variable in class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
logger - Variable in class org.springframework.integration.endpoint.ConcurrentHandler
 
logger - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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
 
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

map - Variable in class org.springframework.integration.message.SimpleMessageStore
 
mapper - Variable in class org.springframework.integration.adapter.AbstractSourceAdapter
 
mapper - Variable in class org.springframework.integration.adapter.AbstractTargetAdapter
 
mapper - Variable in class org.springframework.integration.aop.MessagePublishingInterceptor
 
MAX_SIZE_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
maxMessagesPerTask - Variable in class org.springframework.integration.adapter.PollingSourceAdapter
 
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.ConcurrentHandler.HandlerTask
 
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_BEAN_NAME - Static variable in class org.springframework.integration.config.MessageBusParser
 
MESSAGE_BUS_CLASS - Static variable in class org.springframework.integration.config.MessageBusParser
 
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.config.MessageEndpointAnnotationPostProcessor
 
messageBus - Variable in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
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.
MessageDeliveryException - Exception in org.springframework.integration.message
Exception that indicates an error during message delivery.
MessageDeliveryException() - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDeliveryException(Message<?>) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDeliveryException(String) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDeliveryException(Message<?>, String) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDeliveryException(String, Throwable) - Constructor for exception org.springframework.integration.message.MessageDeliveryException
 
MessageDispatcher - Interface in org.springframework.integration.dispatcher
Strategy interface for dispatching messages.
MessageDistributor - Interface in org.springframework.integration.dispatcher
Strategy interface for distributing a Message to one or more MessageHandlers.
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() - 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() - Constructor for exception org.springframework.integration.handler.MessageHandlerRejectedExecutionException
 
MessageHandlerRejectedExecutionException(Throwable) - Constructor for exception org.springframework.integration.handler.MessageHandlerRejectedExecutionException
 
MessageHandlerRejectedExecutionException(String, 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() - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(Message<?>) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(String) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(Message<?>, String) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHandlingException(String, Throwable) - Constructor for exception org.springframework.integration.message.MessageHandlingException
 
MessageHeader - Class in org.springframework.integration.message
A holder for Message metadata.
MessageHeader() - Constructor for class org.springframework.integration.message.MessageHeader
 
messageHolder - Static variable in class org.springframework.integration.dispatcher.SynchronousChannel
 
MessageMapper<M,O> - Interface in org.springframework.integration.message
Strategy interface for mapping between messages and objects.
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
 
MessageRetriever - Interface in org.springframework.integration.dispatcher
Strategy interface for retrieving messages.
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.
MessageSelectorRejectedException - Exception in org.springframework.integration.message.selector
An exception indicating that a message was rejected by an implementation of MessageSelector.
MessageSelectorRejectedException() - Constructor for exception org.springframework.integration.message.selector.MessageSelectorRejectedException
 
MessageSelectorRejectedException(String) - Constructor for exception org.springframework.integration.message.selector.MessageSelectorRejectedException
 
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.ResponseCorrelator
 
MessageStore - Interface in org.springframework.integration.message
Strategy interface for storing and retrieving messages.
MessagingConfigurationException - Exception in org.springframework.integration
Exception that indicates an incorrectly configured messaging component.
MessagingConfigurationException(String) - Constructor for exception org.springframework.integration.MessagingConfigurationException
 
MessagingConfigurationException(String, Throwable) - Constructor for exception org.springframework.integration.MessagingConfigurationException
 
MessagingException - Exception in org.springframework.integration
The base exception for any failures within the messaging system.
MessagingException() - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(String) - Constructor for exception org.springframework.integration.MessagingException
 
MessagingException(String, Throwable) - Constructor for exception org.springframework.integration.MessagingException
 
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.
MessagingTaskSchedulerAware - Interface in org.springframework.integration.scheduling
Callback interface for components that require the MessagingTaskScheduler.
method - Variable in class org.springframework.integration.adapter.MethodInvokingSource
 
method - Variable in class org.springframework.integration.adapter.MethodInvokingTarget
 
method - Variable in class org.springframework.integration.router.AggregatorAdapter
 
method - Variable in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
method - Variable in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
method - Variable in class org.springframework.integration.util.SimpleMethodInvoker
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelAdapterParser
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
METHOD_NAME_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
METHOD_NAME_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
MethodInvokingSource<T> - Class in org.springframework.integration.adapter
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.adapter.MethodInvokingSource
 
MethodInvokingSource.MessageReceivingMethodValidator - Class in org.springframework.integration.adapter
 
MethodInvokingSource.MessageReceivingMethodValidator() - Constructor for class org.springframework.integration.adapter.MethodInvokingSource.MessageReceivingMethodValidator
 
MethodInvokingTarget<T> - Class in org.springframework.integration.adapter
A messaging target that invokes the specified method on the provided object.
MethodInvokingTarget() - Constructor for class org.springframework.integration.adapter.MethodInvokingTarget
 
methodName - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
MethodValidator - Interface in org.springframework.integration.util
Interface for method validation.
methodValidator - Variable in class org.springframework.integration.util.SimpleMethodInvoker
 
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
 

N

name - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
name - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 

O

object - Variable in class org.springframework.integration.adapter.MethodInvokingSource
 
object - Variable in class org.springframework.integration.adapter.MethodInvokingTarget
 
object - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
object - Variable in class org.springframework.integration.util.SimpleMethodInvoker
 
OBJECT_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
OBJECT_PROPERTY - Static variable in class org.springframework.integration.config.HandlerParser
 
onSend(T) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
Callback method invoked after an item is sent to the channel.
order - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
org.springframework.integration - package org.springframework.integration
 
org.springframework.integration.adapter - package org.springframework.integration.adapter
 
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.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.handler - package org.springframework.integration.handler
 
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.scheduling - package org.springframework.integration.scheduling
 
org.springframework.integration.transformer - package org.springframework.integration.transformer
 
org.springframework.integration.util - package org.springframework.integration.util
 
ORIGINAL_MESSAGE_ID_KEY - Static variable in class org.springframework.integration.channel.interceptor.WireTap
key for the attribute containing the original Message's id

P

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.ChannelAdapterParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.ChannelParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.EndpointParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.HandlerParser
 
parseAggregatorElement(Element, ParserContext, boolean) - Method in class org.springframework.integration.config.AggregatorParser
 
parseConcurrencyPolicy(Element, RootBeanDefinition) - Method in class org.springframework.integration.config.EndpointParser
 
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, ParserContext) - Method in class org.springframework.integration.config.EndpointParser
 
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
 
parseSchedule(Element) - Method in class org.springframework.integration.config.EndpointParser
 
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.ChannelAdapterParser
 
PERIOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
pointcut - Variable in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
poll(int) - Method in class org.springframework.integration.adapter.MethodInvokingSource
 
poll(int) - Method in interface org.springframework.integration.adapter.PollableSource
 
PollableSource<T> - Interface in org.springframework.integration.adapter
Interface for any external data source that can be polled.
Polled - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of providing messages.
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.
PollingSourceAdapter<T> - Class in org.springframework.integration.adapter
A channel adapter that retrieves objects from a PollableSource, delegates to a MessageMapper to create messages from those objects, and then sends the resulting messages to the provided MessageChannel.
PollingSourceAdapter(PollableSource<T>) - Constructor for class org.springframework.integration.adapter.PollingSourceAdapter
Create a new adapter for the given source.
PollingSourceAdapter() - Constructor for class org.springframework.integration.adapter.PollingSourceAdapter
No-arg constructor for providing source after construction.
PollingSourceAdapter.PollingSourceAdapterTask - Class in org.springframework.integration.adapter
 
PollingSourceAdapter.PollingSourceAdapterTask() - Constructor for class org.springframework.integration.adapter.PollingSourceAdapter.PollingSourceAdapterTask
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.MessageBusParser
 
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.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
 
prepare(Object) - Method in interface org.springframework.integration.adapter.ArgumentListPreparer
 
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
 
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
 
processMessages() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
properties - Variable in class org.springframework.integration.message.MessageHeader
 
PROPERTY_KEY - Static variable in class org.springframework.integration.router.RouterMessageHandlerAdapter
 
PUBLISH_SUBSCRIBE_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelParser
 
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(MessageSelector) - Method in class org.springframework.integration.channel.BaseBlockingQueueChannel
 
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.dispatcher.SynchronousChannel
Remove and return any messages that are stored for the current thread and do not match the provided selector.
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.BaseBlockingQueueChannel
 
QUEUE_CAPACITY_ATTRIBUTE - Static variable in class org.springframework.integration.config.IntegrationNamespaceUtils
 
queueCapacity - Variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 

R

RandomUuidGenerator - Class in org.springframework.integration.util
An id generator that generates random UUIDs.
RandomUuidGenerator() - Constructor for class org.springframework.integration.util.RandomUuidGenerator
 
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.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 interface org.springframework.integration.channel.MessageChannel
Receive a message, blocking indefinitely if necessary.
receive(long) - Method in interface org.springframework.integration.channel.MessageChannel
Receive a message, blocking until either a message is available or the specified timeout period elapses.
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
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.AggregatorParser
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.ChannelAdapterParser
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
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
 
registerDefaultConcurrencyIfAvailable(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.MessageBusParser
 
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
 
registerSourceAdapter(String, SourceAdapter) - Method in class org.springframework.integration.bus.MessageBus
 
registerSourceAdapters(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
registerWithDispatcher(MessageChannel, MessageHandler, Schedule) - Method in class org.springframework.integration.bus.MessageBus
 
rejectionLimit - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
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
 
removeBarrier(Object) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
removeEldestEntry(Map.Entry<K, V>) - Method in class org.springframework.integration.util.BoundedHashMap
 
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.DefaultMessageDistributor
 
removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDistributor
 
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.SynchronousChannel
 
REPLY_HANDLER_ATTRIBUTE - Static variable in class org.springframework.integration.config.EndpointParser
 
REPLY_HANDLER_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
replyHandler - Variable in class org.springframework.integration.endpoint.ConcurrentHandler
 
replyHandler - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
ReplyHandler - Interface in org.springframework.integration.handler
Strategy interface for handling reply messages.
replyTimeout - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
request(Message<?>, long, long) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Send a request message and wait for a reply message using the provided timeout values.
request(Message<?>) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Send a request message and wait for a reply message using the default timeout values.
request(Message<?>, ReplyHandler, long, long) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Send a request message asynchronously to be handled by the provided ReplyHandler.
request(Message<?>, ReplyHandler) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Send a request message asynchronously to be handled by the provided ReplyHandler.
requestChannel - Variable in class org.springframework.integration.channel.RequestReplyTemplate
 
RequestReplyTemplate - Class in org.springframework.integration.channel
A template that facilitates the implementation of request-reply usage scenarios above one-way MessageChannels.
RequestReplyTemplate(MessageChannel, ExecutorService) - Constructor for class org.springframework.integration.channel.RequestReplyTemplate
Create a RequestReplyTemplate.
RequestReplyTemplate(MessageChannel) - Constructor for class org.springframework.integration.channel.RequestReplyTemplate
Create a RequestReplyTemplate with a default single-threaded executor.
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
 
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
 
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
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.MessageBusParser
 
resolveReplyChannel(MessageHeader) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
resolveReplyChannelFromMessage(Message<?>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
ResponseCorrelator - Class in org.springframework.integration.handler
A handler for receiving messages from a "reply channel".
ResponseCorrelator(int) - Constructor for class org.springframework.integration.handler.ResponseCorrelator
 
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
 
retrieveMessages() - Method in class org.springframework.integration.dispatcher.ChannelPollingMessageRetriever
 
retrieveMessages() - Method in interface org.springframework.integration.dispatcher.MessageRetriever
 
retriever - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
retryInterval - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
returnAddress - Variable in class org.springframework.integration.message.MessageHeader
 
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, Map<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
 
run() - Method in class org.springframework.integration.adapter.PollingSourceAdapter.PollingSourceAdapterTask
 
run() - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher.DispatcherTask
 
run() - Method in class org.springframework.integration.endpoint.ConcurrentHandler.HandlerTask
 
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.adapter.PollingSourceAdapter
 
running - Variable in class org.springframework.integration.bus.MessageBus
 
running - Variable in class org.springframework.integration.channel.interceptor.WireTap
 
running - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
running - Variable in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
running - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 

S

schedule - Variable in class org.springframework.integration.adapter.PollingSourceAdapter
 
schedule - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher.DispatcherTask
 
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.EndpointParser
 
scheduledHandlers - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
scheduleDispatcherTask(Schedule) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
scheduler - Variable in class org.springframework.integration.adapter.PollingSourceAdapter
 
scheduler - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
SchedulingMessageDispatcher - Interface in org.springframework.integration.dispatcher
An extension to the MessageDispatcher strategy for handlers that may be scheduled.
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.transformer.MessageFilter
 
SELECTOR_ELEMENT - Static variable in class org.springframework.integration.config.EndpointParser
 
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.endpoint.DefaultMessageEndpoint
 
SELECTORS_PROPERTY - Static variable in class org.springframework.integration.config.EndpointParser
 
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(Object) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
send(T) - Method in interface org.springframework.integration.adapter.Target
 
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 interface org.springframework.integration.channel.MessageChannel
Send a message, blocking indefinitely if necessary.
send(Message, long) - Method in interface org.springframework.integration.channel.MessageChannel
Send a message, blocking until either the message is accepted or the specified timeout period elapses.
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
 
sendMesage(Message<?>, MessageChannel) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
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.adapter.AbstractSourceAdapter
 
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
 
sendToChannel(T) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
sendToDiscardChannelIfAvailable(Message<?>) - Method in class org.springframework.integration.router.AggregatingMessageHandler
 
sendToTarget(T) - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
sendToTarget(T) - Method in class org.springframework.integration.adapter.DefaultTargetAdapter
 
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
 
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
setArgumentListPreparer(ArgumentListPreparer) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
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.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
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.DefaultMessageEndpoint
 
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
setChannel(MessageChannel) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
setChannel(MessageChannel) - Method in interface org.springframework.integration.adapter.SourceAdapter
 
setChannelMappings(Map<Class<?>, MessageChannel>) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
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.DefaultMessageEndpoint
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
 
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.DefaultMessageEndpoint
 
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
 
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.
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
Set the name of the channel to which this endpoint should send reply messages by default.
setDefaultReceiveTimeout(long) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Set the default timeout value for receiving reply messages.
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.dispatcher.DefaultMessageDispatcher
 
setDefaultSchedule(Schedule) - Method in interface org.springframework.integration.dispatcher.SchedulingMessageDispatcher
 
setDefaultSendTimeout(long) - Method in class org.springframework.integration.channel.RequestReplyTemplate
Set the default timeout value for sending request messages.
setDefaultTimeout(long) - Method in class org.springframework.integration.handler.ResponseCorrelator
 
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.
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.ConcurrentHandler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setErrorHandler(ErrorHandler) - Method in interface org.springframework.integration.scheduling.MessagingTaskScheduler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setExpectsMessage(boolean) - Method in class org.springframework.integration.handler.DefaultMessageHandlerAdapter
Specify whether the handler should pass the message when invoking the target method.
setExpiration(Date) - Method in class org.springframework.integration.message.MessageHeader
Set the expiration date for this message or null to indicate 'never expire'.
setFixedRate(boolean) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setHandler(MessageHandler) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
Set the handler to be invoked for each consumed message.
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setIdGenerator(IdGenerator) - Method in class org.springframework.integration.message.AbstractMessageMapper
 
setInitialDelay(long) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setInitialDelay(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setKeepAliveSeconds(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the maximum number of messages for each retrieval attempt.
setMaxSize(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setMessageBus(MessageBus) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setMessageMapper(MessageMapper<?, T>) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
setMessageMapper(MessageMapper<?, T>) - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
setMessageMapper(MessageMapper) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Specify the MessageMapper to use when creating a message from the return value Object.
setMessageSelectors(List<MessageSelector>) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setMessagingTaskScheduler(MessagingTaskScheduler) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setMessagingTaskScheduler(MessagingTaskScheduler) - Method in interface org.springframework.integration.scheduling.MessagingTaskSchedulerAware
 
setMethod(String) - Method in class org.springframework.integration.adapter.MethodInvokingSource
 
setMethod(String) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
setMethodName(String) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMethodValidator(MethodValidator) - Method in class org.springframework.integration.util.SimpleMethodInvoker
 
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.DefaultMessageEndpoint
 
setObject(T) - Method in class org.springframework.integration.adapter.MethodInvokingSource
 
setObject(T) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
setObject(T) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setOrder(int) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setPeriod(long) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setPeriod(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
Set the polling period.
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.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.
setRejectionLimit(int) - Method in class org.springframework.integration.channel.DispatcherPolicy
Set the maximum number of retries upon rejection.
setReplyHandler(ReplyHandler) - Method in class org.springframework.integration.endpoint.ConcurrentHandler
 
setReplyHandler(ReplyHandler) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setReplyTimeout(long) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
Set the timeout in milliseconds to be enforced when this endpoint sends a reply message.
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
 
setScheduledExecutorService(ScheduledExecutorService) - Method in class org.springframework.integration.bus.MessageBus
Set the ScheduledExecutorService to use for scheduling message dispatchers.
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 class org.springframework.integration.adapter.AbstractSourceAdapter
 
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
 
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
 
setSource(PollableSource<T>) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setSubscriberAnnotationType(Class<? extends Annotation>) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setSubscription(Subscription) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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
 
setTrackedCorrelationIdCapacity(int) - Method in class org.springframework.integration.router.AggregatingMessageHandler
Set the number of completed correlationIds to track.
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
shouldFailOnRejectionLimit - Variable in class org.springframework.integration.channel.DispatcherPolicy
 
shouldRepeat - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
SimpleChannel - Class in org.springframework.integration.channel
Simple implementation of a message channel.
SimpleChannel(int, DispatcherPolicy) - Constructor for class org.springframework.integration.channel.SimpleChannel
Create a channel with the specified queue capacity and dispatcher policy.
SimpleChannel(int) - Constructor for class org.springframework.integration.channel.SimpleChannel
Create a channel with the specified queue capacity.
SimpleChannel() - Constructor for class org.springframework.integration.channel.SimpleChannel
Create a channel with the default queue capacity.
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
 
SimpleMessagingTaskScheduler - Class in org.springframework.integration.scheduling
An implementation of MessagingTaskScheduler that understands PollingSchedules.
SimpleMessagingTaskScheduler(int) - Constructor for class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
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
 
SimpleMethodInvoker<T> - Class in org.springframework.integration.util
A simple wrapper for MethodInvoker.
SimpleMethodInvoker(T, String) - Constructor for class org.springframework.integration.util.SimpleMethodInvoker
 
SimplePayloadMessageMapper<T> - Class in org.springframework.integration.message
A MessageMapper implementation that simply wraps and unwraps a payload object in a Message.
SimplePayloadMessageMapper() - Constructor for class org.springframework.integration.message.SimplePayloadMessageMapper
 
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() - 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
 
source - Variable in class org.springframework.integration.adapter.PollingSourceAdapter
 
source - Variable in class org.springframework.integration.dispatcher.SynchronousChannel
 
SourceAdapter - Interface in org.springframework.integration.adapter
Base interface for source adapters.
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 which are then sent to the channel whose name is provided with the 'channel' attribute.
SplitterMessageHandlerAdapter<T> - Class in org.springframework.integration.router
MessageHandler adapter for methods annotated with @Splitter.
SplitterMessageHandlerAdapter(T, Method, Map<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
 
start() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
start() - Method in class org.springframework.integration.bus.MessageBus
 
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.dispatcher.DefaultMessageDispatcher
 
start() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
start() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
starting - Variable in class org.springframework.integration.adapter.PollingSourceAdapter
 
starting - Variable in class org.springframework.integration.bus.MessageBus
 
starting - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
stop() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
stop() - Method in class org.springframework.integration.bus.MessageBus
 
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
stop() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
stop() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
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
 
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.DefaultMessageEndpoint
 
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.EndpointParser
 
SynchronousChannel - 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).
SynchronousChannel() - Constructor for class org.springframework.integration.dispatcher.SynchronousChannel
 
SynchronousChannel(PollableSource<?>) - Constructor for class org.springframework.integration.dispatcher.SynchronousChannel
 
SynchronousChannel.ThreadLocalMessageHolder - Class in org.springframework.integration.dispatcher
 
SynchronousChannel.ThreadLocalMessageHolder() - Constructor for class org.springframework.integration.dispatcher.SynchronousChannel.ThreadLocalMessageHolder
 

T

target - Variable in class org.springframework.integration.adapter.DefaultTargetAdapter
 
Target<T> - Interface in org.springframework.integration.adapter
Interface for any external target that may receive data from an outgoing channel adapter.
target - Variable in class org.springframework.integration.handler.InterceptingMessageHandler
 
targetMessageStore - Variable in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
task - Variable in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler.MessagingTaskRunner
 
taskScheduler - Variable in class org.springframework.integration.bus.MessageBus
 
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
 
toMessage(O) - Method in interface org.springframework.integration.message.MessageMapper
Map to a Message from the given object.
toMessage(T) - Method in class org.springframework.integration.message.SimplePayloadMessageMapper
Return a Message with the given object as its payload.
toString() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
toString() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
toString() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
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.scheduling.PollingSchedule
 
totalMessagesProcessed - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
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
 

U

undeliveredMessage - Variable in exception org.springframework.integration.message.MessageDeliveryException
 
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
 

V

validate(Method) - Method in class org.springframework.integration.adapter.MethodInvokingSource.MessageReceivingMethodValidator
 
validate() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
Subclasses may override this method to provide validation upon initialization.
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.
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.

W

waitForMessage(Object, long, boolean) - Method in class org.springframework.integration.message.RetrievalBlockingMessageStore
 
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.

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