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

A

AbstractFileMapper<T> - Class in org.springframework.integration.adapter.file
Base class providing common behavior for file-based message mappers.
AbstractFileMapper(File) - Constructor for class org.springframework.integration.adapter.file.AbstractFileMapper
 
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 UidGenerator 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
 
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.
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.DispatcherTask
 
addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
addHandler(MessageHandler, Schedule) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
addMessageSelector(MessageSelector) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
afterPropertiesSet() - Method in class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
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.handler.ConcurrentHandler
 
afterPropertiesSet() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
afterPropertiesSet() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
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
 
ApplicationEventSourceAdapter - Class in org.springframework.integration.adapter.event
A source adapter for passing Spring ApplicationEvents within messages.
ApplicationEventSourceAdapter() - Constructor for class org.springframework.integration.adapter.event.ApplicationEventSourceAdapter
 
ApplicationEventTargetAdapter - Class in org.springframework.integration.adapter.event
A target adapter for publishing MessagingEvents.
ApplicationEventTargetAdapter() - Constructor for class org.springframework.integration.adapter.event.ApplicationEventTargetAdapter
 
ArgumentListPreparer - Interface in org.springframework.integration.adapter
A strategy for preparing an argument list from a single source object.

B

ByteArrayFileMapper - Class in org.springframework.integration.adapter.file
A MessageMapper implementation for messages with a byte array payload.
ByteArrayFileMapper(File) - Constructor for class org.springframework.integration.adapter.file.ByteArrayFileMapper
 
ByteStreamSource - Class in org.springframework.integration.adapter.stream
A pollable source for receiving bytes from an InputStream.
ByteStreamSource(InputStream) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamSource
 
ByteStreamSource(InputStream, int) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamSource
 
ByteStreamSourceAdapter - Class in org.springframework.integration.adapter.stream
A polling source adapter that wraps a ByteStreamSource.
ByteStreamSourceAdapter(InputStream) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamSourceAdapter
 
ByteStreamTargetAdapter - Class in org.springframework.integration.adapter.stream
A target adapter that writes a byte array to an OutputStream.
ByteStreamTargetAdapter(OutputStream) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamTargetAdapter
 
ByteStreamTargetAdapter(OutputStream, int) - Constructor for class org.springframework.integration.adapter.stream.ByteStreamTargetAdapter
 

C

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
 
ChannelNameResolver - Interface in org.springframework.integration.router
Strategy interface for content-based routing to a channel name.
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
 
ChannelPublishingJmsListener - Class in org.springframework.integration.adapter.jms
JMS MessageListener implementation that converts the received JMS message into a Spring Integration message and then sends that to a channel.
ChannelPublishingJmsListener() - Constructor for class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
ChannelPublishingJmsListener(MessageChannel) - Constructor for class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
ChannelRegistry - Interface in org.springframework.integration.channel
A strategy interface for registration and lookup of message channels by name.
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.
CharacterStreamSource - Class in org.springframework.integration.adapter.stream
A pollable source for text-based InputStreams.
CharacterStreamSource(InputStream) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamSource
 
CharacterStreamSource(InputStream, int) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamSource
 
CharacterStreamSourceAdapter - Class in org.springframework.integration.adapter.stream
A polling source adapter that wraps a CharacterStreamSource.
CharacterStreamSourceAdapter(InputStream) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamSourceAdapter
 
CharacterStreamTargetAdapter - Class in org.springframework.integration.adapter.stream
A target adapter that writes to an OutputStream.
CharacterStreamTargetAdapter(OutputStream) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
 
CharacterStreamTargetAdapter(OutputStream, int) - Constructor for class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
 
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
 
ConcurrentHandler - Class in org.springframework.integration.handler
A MessageHandler implementation that encapsulates a ThreadPoolTaskExecutor and delegates to a wrapped handler for concurrent, asynchronous message handling.
ConcurrentHandler(MessageHandler) - Constructor for class org.springframework.integration.handler.ConcurrentHandler
 
ConcurrentHandler(MessageHandler, ConcurrencyPolicy) - Constructor for class org.springframework.integration.handler.ConcurrentHandler
 
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
 

D

DEFAULT_CAPACITY - Static variable in class org.springframework.integration.channel.SimpleChannel
 
DEFAULT_CORE_SIZE - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
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.dispatcher.DispatcherPolicy
 
DEFAULT_MAX_SIZE - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_QUEUE_CAPACITY - Static variable in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.dispatcher.DispatcherPolicy
 
DEFAULT_REJECTION_LIMIT - Static variable in class org.springframework.integration.dispatcher.DispatcherPolicy
 
DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.dispatcher.DispatcherPolicy
 
DefaultChannelRegistry - Class in org.springframework.integration.channel
A simple map-backed implementation of ChannelRegistry.
DefaultChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultChannelRegistry
 
DefaultFileNameGenerator - Class in org.springframework.integration.adapter.file
Default implementation of the filename generator strategy.
DefaultFileNameGenerator() - Constructor for class org.springframework.integration.adapter.file.DefaultFileNameGenerator
 
DefaultMessageDispatcher - Class in org.springframework.integration.dispatcher
Default implementation of MessageDispatcher.
DefaultMessageDispatcher(MessageChannel) - Constructor for class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
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
 
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.
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
 
destroy() - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
dispatch() - Method in class org.springframework.integration.dispatcher.DispatcherTask
Retrieves messages and dispatches to the executors.
DispatcherPolicy - Class in org.springframework.integration.dispatcher
Metadata for a MessageDispatcher.
DispatcherPolicy() - Constructor for class org.springframework.integration.dispatcher.DispatcherPolicy
 
DispatcherPolicy(boolean) - Constructor for class org.springframework.integration.dispatcher.DispatcherPolicy
Create a DispatcherPolicy.
DispatcherTask - Class in org.springframework.integration.dispatcher
A task for polling MessageDispatchers.
DispatcherTask(MessageChannel) - Constructor for class org.springframework.integration.dispatcher.DispatcherTask
 
dispatchMessage(Message<?>) - Method in class org.springframework.integration.dispatcher.DispatcherTask
 
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.handler.config.RouterMessageHandlerCreator
 
doCreateHandler(Object, Method, Map<String, ?>) - Method in class org.springframework.integration.handler.config.SplitterMessageHandlerCreator
 
doHandle(Message, SimpleMethodInvoker) - 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) - Method in class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.file.config.FileSourceAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.file.config.FileTargetAdapterParser
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.jms.config.JmsSourceAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.adapter.jms.config.JmsTargetAdapterParser
 

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.
equals(Object) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
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.

F

FILENAME_PROPERTY_KEY - Static variable in interface org.springframework.integration.adapter.file.FileNameGenerator
 
FileNameGenerator - Interface in org.springframework.integration.adapter.file
Strategy interface for generating a file name from a message.
FileSource - Class in org.springframework.integration.adapter.file
A messaging source that polls a directory to retrieve files.
FileSource(File) - Constructor for class org.springframework.integration.adapter.file.FileSource
 
FileSourceAdapter - Class in org.springframework.integration.adapter.file
Channel adapter for polling a directory and creating messages from its files.
FileSourceAdapter(File, MessageChannel, int) - Constructor for class org.springframework.integration.adapter.file.FileSourceAdapter
 
FileSourceAdapter(File, MessageChannel, int, boolean) - Constructor for class org.springframework.integration.adapter.file.FileSourceAdapter
 
FileSourceAdapterParser - Class in org.springframework.integration.adapter.file.config
Parser for the <file-source/> element.
FileSourceAdapterParser() - Constructor for class org.springframework.integration.adapter.file.config.FileSourceAdapterParser
 
FileTargetAdapter - Class in org.springframework.integration.adapter.file
A convenience adapter for writing files.
FileTargetAdapter(File) - Constructor for class org.springframework.integration.adapter.file.FileTargetAdapter
 
FileTargetAdapter(File, boolean) - Constructor for class org.springframework.integration.adapter.file.FileTargetAdapter
 
FileTargetAdapterParser - Class in org.springframework.integration.adapter.file.config
Parser for the <file-target/> element.
FileTargetAdapterParser() - Constructor for class org.springframework.integration.adapter.file.config.FileTargetAdapterParser
 
fromMessage(Message<T>) - Method in class org.springframework.integration.adapter.event.MessagingEventMapper
 
fromMessage(Message<T>) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
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

generateFileName(Message<?>) - Method in class org.springframework.integration.adapter.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.adapter.file.FileNameGenerator
 
generateUid() - Method in class org.springframework.integration.util.RandomGuidUidGenerator
 
generateUid() - Method in interface org.springframework.integration.util.UidGenerator
Generate a new unique id.
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.
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.adapter.file.config.FileSourceAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.file.config.FileTargetAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.jms.config.JmsSourceAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.adapter.jms.config.JmsTargetAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.MessageBusParser
 
getChannel() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
getChannel() - Method in class org.springframework.integration.bus.Subscription
 
getChannelName() - Method in class org.springframework.integration.bus.Subscription
 
getChannelRegistry() - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
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() - Method in class org.springframework.integration.message.MessageHeader
 
getDefaultOutputChannelName() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
getDispatcherPolicy() - Method in interface org.springframework.integration.channel.MessageChannel
Return this channel's dispatcher policy
getDispatcherPolicy() - Method in class org.springframework.integration.channel.SimpleChannel
 
getErrorChannel() - Method in class org.springframework.integration.bus.MessageBus
 
getErrorChannel() - Method in interface org.springframework.integration.channel.ChannelRegistry
 
getErrorChannel() - Method in class org.springframework.integration.channel.DefaultChannelRegistry
 
getExpiration() - Method in class org.springframework.integration.message.MessageHeader
Return the expiration date for this message or null to indicate 'never expire'.
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
 
getInitialDelay() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getKeepAliveSeconds() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getMapper() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
getMaxMessagesPerTask() - Method in class org.springframework.integration.dispatcher.DispatcherPolicy
Return the maximum number of messages for each retrieval attempt.
getMaxSize() - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
getMessage() - Method in class org.springframework.integration.adapter.event.MessagingEvent
 
getMessageMapper() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
getMessageMapper() - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
getMethodName() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
getName() - Method in interface org.springframework.integration.channel.MessageChannel
Return the name of this channel.
getName() - Method in class org.springframework.integration.channel.SimpleChannel
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
 
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.dispatcher.DispatcherPolicy
Return the maximum amount of time in milliseconds to wait for a message to be available.
getRejectionLimit() - Method in class org.springframework.integration.dispatcher.DispatcherPolicy
Return the maximum number of retries upon rejection.
getReplyChannelName() - Method in class org.springframework.integration.message.MessageHeader
 
getRetryInterval() - Method in class org.springframework.integration.dispatcher.DispatcherPolicy
Return the amount of time in milliseconds to wait between rejections.
getSchedule() - Method in class org.springframework.integration.bus.Subscription
 
getSchedule() - Method in class org.springframework.integration.dispatcher.DispatcherTask
 
getSchedule() - Method in interface org.springframework.integration.scheduling.MessagingTask
 
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.dispatcher.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.
getTimeUnit() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
getUidGenerator() - Method in class org.springframework.integration.message.AbstractMessageMapper
 

H

handle(Message) - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
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.ConcurrentHandler
 
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.router.AbstractRoutingMessageHandler
 
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.
hasErrorHandler() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
hashCode() - Method in class org.springframework.integration.scheduling.PollingSchedule
 

I

init() - Method in class org.springframework.integration.config.IntegrationNamespaceHandler
 
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.jms.JmsMessageDrivenSourceAdapter
 
initialize() - Method in class org.springframework.integration.bus.MessageBus
 
IntegrationNamespaceHandler - Class in org.springframework.integration.config
Namespace handler for the integration namespace.
IntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.IntegrationNamespaceHandler
 
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
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Invoke the target method and publish its return value.
invokeMethod(Object...) - Method in class org.springframework.integration.util.SimpleMethodInvoker
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.MessageBusParser
 
isInitialized() - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
isInitialized() - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
isPublishSubscribe() - Method in class org.springframework.integration.dispatcher.DispatcherPolicy
Return whether the dispatcher should attempt to publish to all of its handlers.
isRunning() - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
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.dispatcher.DefaultMessageDispatcher
 
isRunning() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
isRunning() - Method in class org.springframework.integration.handler.ConcurrentHandler
 
isRunning() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
isSecure() - Method in class org.springframework.integration.util.RandomGuidUidGenerator
Returns whether or not the generated random numbers are secure, meaning cryptographically strong.

J

JmsMessageDrivenSourceAdapter - Class in org.springframework.integration.adapter.jms
A message-driven adapter for receiving JMS messages and sending to a channel.
JmsMessageDrivenSourceAdapter() - Constructor for class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
JmsPollableSource - Class in org.springframework.integration.adapter.jms
A source for receiving JMS Messages with a polling listener.
JmsPollableSource(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.JmsPollableSource
 
JmsPollableSource(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.JmsPollableSource
 
JmsPollableSource(ConnectionFactory, String) - Constructor for class org.springframework.integration.adapter.jms.JmsPollableSource
 
JmsPollableSource() - Constructor for class org.springframework.integration.adapter.jms.JmsPollableSource
No-arg constructor provided for convenience when configuring with setters.
JmsPollingSourceAdapter - Class in org.springframework.integration.adapter.jms
A convenience adapter that wraps a JmsPollableSource.
JmsPollingSourceAdapter(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.JmsPollingSourceAdapter
 
JmsPollingSourceAdapter(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.JmsPollingSourceAdapter
 
JmsPollingSourceAdapter(ConnectionFactory, String) - Constructor for class org.springframework.integration.adapter.jms.JmsPollingSourceAdapter
 
JmsSourceAdapterParser - Class in org.springframework.integration.adapter.jms.config
Parser for the <jms-source/> element.
JmsSourceAdapterParser() - Constructor for class org.springframework.integration.adapter.jms.config.JmsSourceAdapterParser
 
JmsTargetAdapter - Class in org.springframework.integration.adapter.jms
A target adapter for sending JMS Messages.
JmsTargetAdapter(JmsTemplate) - Constructor for class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
JmsTargetAdapter(ConnectionFactory, Destination) - Constructor for class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
JmsTargetAdapter() - Constructor for class org.springframework.integration.adapter.jms.JmsTargetAdapter
No-arg constructor provided for convenience when configuring with setters.
JmsTargetAdapterParser - Class in org.springframework.integration.adapter.jms.config
Parser for the <jms-target/> element.
JmsTargetAdapterParser() - Constructor for class org.springframework.integration.adapter.jms.config.JmsTargetAdapterParser
 

L

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.file.AbstractFileMapper
 
logger - Variable in class org.springframework.integration.aop.MessagePublishingInterceptor
 
logger - Variable in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
logger - Variable in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
logger - Variable in class org.springframework.integration.router.AbstractRoutingMessageHandler
 
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
 

M

Message<T> - Interface in org.springframework.integration.message
The central interface that any Message type must implement.
MESSAGE_BUS_BEAN_NAME - Static variable in class org.springframework.integration.config.MessageBusParser
 
MessageBus - Class in org.springframework.integration.bus
The messaging bus.
MessageBus() - Constructor for class org.springframework.integration.bus.MessageBus
 
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
Exception that indicates an error during message delivery.
MessageDeliveryException() - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDeliveryException(String) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDeliveryException(String, Throwable) - Constructor for exception org.springframework.integration.MessageDeliveryException
 
MessageDispatcher - Interface in org.springframework.integration.dispatcher
Strategy interface for dispatching messages.
MessageEndpoint - Annotation Type in org.springframework.integration.annotation
Indicates that a class is capable of serving as a message endpoint.
MessageEndpoint - Interface in org.springframework.integration.endpoint
Base interface for message endpoints.
MessageEndpointAnnotationPostProcessor - Class in org.springframework.integration.config
A BeanPostProcessor implementation that generates endpoints for classes annotated with @MessageEndpoint.
MessageEndpointAnnotationPostProcessor() - 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
Exception that indicates an error during message handling.
MessageHandlingException() - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHandlingException(String) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHandlingException(String, Throwable) - Constructor for exception org.springframework.integration.MessageHandlingException
 
MessageHeader - Class in org.springframework.integration.message
A holder for Message metadata.
MessageHeader() - Constructor for class org.springframework.integration.message.MessageHeader
 
MessageMapper<M,O> - Interface in org.springframework.integration.message
Strategy interface for mapping between messages and objects.
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.
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
 
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
 
MessagingEvent<T> - Class in org.springframework.integration.adapter.event
A subclass of ApplicationEvent that wraps a Message.
MessagingEvent(Message<T>) - Constructor for class org.springframework.integration.adapter.event.MessagingEvent
 
MessagingEventMapper<T> - Class in org.springframework.integration.adapter.event
A MessageMapper implementation for mapping to and from MessagingEvents.
MessagingEventMapper() - Constructor for class org.springframework.integration.adapter.event.MessagingEventMapper
 
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.
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
 
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
 
MethodValidator - Interface in org.springframework.integration.util
Interface for method validation.
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
 

O

onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.adapter.event.ApplicationEventSourceAdapter
 
onMessage(Message) - Method in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
org.springframework.integration - package org.springframework.integration
 
org.springframework.integration.adapter - package org.springframework.integration.adapter
 
org.springframework.integration.adapter.event - package org.springframework.integration.adapter.event
 
org.springframework.integration.adapter.file - package org.springframework.integration.adapter.file
 
org.springframework.integration.adapter.file.config - package org.springframework.integration.adapter.file.config
 
org.springframework.integration.adapter.jms - package org.springframework.integration.adapter.jms
 
org.springframework.integration.adapter.jms.config - package org.springframework.integration.adapter.jms.config
 
org.springframework.integration.adapter.stream - package org.springframework.integration.adapter.stream
 
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.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.scheduling - package org.springframework.integration.scheduling
 
org.springframework.integration.transformer - package org.springframework.integration.transformer
 
org.springframework.integration.util - package org.springframework.integration.util
 

P

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
 
parseUid(String) - Method in class org.springframework.integration.util.RandomGuidUidGenerator
 
parseUid(String) - Method in interface org.springframework.integration.util.UidGenerator
Convert the string-encoded uid into its original object form.
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
 
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.
poll(int) - Method in class org.springframework.integration.adapter.file.FileSource
 
poll(int) - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
poll(int) - Method in class org.springframework.integration.adapter.MethodInvokingSource
 
poll(int) - Method in interface org.springframework.integration.adapter.PollableSource
 
poll(int) - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
poll(int) - Method in class org.springframework.integration.adapter.stream.CharacterStreamSource
 
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
 
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
 
prefersShortLivedTasks() - Method in class org.springframework.integration.scheduling.AbstractMessagingTaskScheduler
 
prepare(Object) - Method in interface org.springframework.integration.adapter.ArgumentListPreparer
 
processMessages() - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
Publisher - Annotation Type in org.springframework.integration.annotation
Indicates that the method's return value should be published to the specified channel.
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
 

R

RandomGuid - Class in org.springframework.integration.util
Globally unique identifier generator.
RandomGuid() - Constructor for class org.springframework.integration.util.RandomGuid
Default constructor.
RandomGuid(boolean) - Constructor for class org.springframework.integration.util.RandomGuid
Constructor with security option.
RandomGuidUidGenerator - Class in org.springframework.integration.util
An id generator that uses the RandomGuid support class.
RandomGuidUidGenerator() - Constructor for class org.springframework.integration.util.RandomGuidUidGenerator
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.ByteArrayFileMapper
 
readMessagePayload(File) - Method in class org.springframework.integration.adapter.file.TextFileMapper
 
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.
receive() - Method in class org.springframework.integration.channel.SimpleChannel
Receive the message at the head of the queue.
receive(long) - Method in class org.springframework.integration.channel.SimpleChannel
Receive the message at the head of the queue.
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
 
refreshExecutor() - Method in class org.springframework.integration.handler.ConcurrentHandler
 
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
 
registerEndpoint(String, MessageEndpoint) - 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
 
ReplyHandler - Interface in org.springframework.integration.handler
Strategy interface for handling reply messages.
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
 
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.
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
 
retrieveMessages() - Method in class org.springframework.integration.dispatcher.ChannelPollingMessageRetriever
 
retrieveMessages() - Method in interface org.springframework.integration.dispatcher.MessageRetriever
 
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.handler.config
Creates a MessageHandler adapter for router methods.
RouterMessageHandlerCreator() - Constructor for class org.springframework.integration.handler.config.RouterMessageHandlerCreator
 
run() - Method in class org.springframework.integration.dispatcher.DispatcherTask
 

S

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
 
send(Object) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
send(T) - Method in interface org.springframework.integration.adapter.Target
 
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(Message) - Method in class org.springframework.integration.channel.SimpleChannel
Send a message on this channel.
send(Message, long) - Method in class org.springframework.integration.channel.SimpleChannel
Send a message on this channel.
sendToChannel(T) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
sendToTarget(T) - Method in class org.springframework.integration.adapter.AbstractTargetAdapter
 
sendToTarget(T) - Method in class org.springframework.integration.adapter.DefaultTargetAdapter
 
sendToTarget(MessagingEvent) - Method in class org.springframework.integration.adapter.event.ApplicationEventTargetAdapter
 
sendToTarget(File) - Method in class org.springframework.integration.adapter.file.FileTargetAdapter
 
sendToTarget(Object) - Method in class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
sendToTarget(Object) - Method in class org.springframework.integration.adapter.stream.ByteStreamTargetAdapter
 
sendToTarget(Object) - Method in class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.bus.MessageBus
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.adapter.event.ApplicationEventTargetAdapter
 
setArgumentListPreparer(ArgumentListPreparer) - Method in class org.springframework.integration.adapter.MethodInvokingTarget
 
setAttribute(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.
setBackupDirectory(File) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
setBackupDirectory(File) - Method in class org.springframework.integration.adapter.file.FileSourceAdapter
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.PublisherAnnotationPostProcessor
 
setBeanName(String) - Method in class org.springframework.integration.channel.SimpleChannel
Set the name of this channel to its bean name.
setBeanName(String) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setBytesPerMessage(int) - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
setBytesPerMessage(int) - Method in class org.springframework.integration.adapter.stream.ByteStreamSourceAdapter
 
setChannel(MessageChannel) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
setChannel(MessageChannel) - Method in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
setChannel(MessageChannel) - Method in interface org.springframework.integration.adapter.SourceAdapter
 
setChannel(MessageChannel) - Method in class org.springframework.integration.bus.Subscription
 
setChannelMappings(Map<Class<?>, MessageChannel>) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
setChannelName(String) - Method in class org.springframework.integration.bus.Subscription
 
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
 
setConcurrencyPolicy(ConcurrencyPolicy) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
setContainer(AbstractJmsListeningContainer) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setCorePoolSize(int) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
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
 
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
Set the name of the channel to which this endpoint can send reply messages by default.
setDefaultSchedule(Schedule) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
setDestination(Destination) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setDestination(Destination) - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
setDestination(Destination) - Method in class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
setDestinationName(String) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setDestinationName(String) - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
setDispatcherPoolSize(int) - Method in class org.springframework.integration.bus.MessageBus
Set the size for the dispatcher thread pool.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.bus.MessageBus
 
setErrorChannel(MessageChannel) - Method in interface org.springframework.integration.channel.ChannelRegistry
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.DefaultChannelRegistry
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.scheduling.MessagePublishingErrorHandler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.handler.ConcurrentHandler
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setEventTypes(List<Class<? extends ApplicationEvent>>) - Method in class org.springframework.integration.adapter.event.ApplicationEventSourceAdapter
Set the list of event types (classes that extend ApplicationEvent) that this adapter should send to the message channel.
setExecutor(ThreadPoolTaskExecutor) - Method in class org.springframework.integration.handler.ConcurrentHandler
 
setExecutor(ScheduledExecutorService) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setExpiration(Date) - Method in class org.springframework.integration.message.MessageHeader
Set the expiration date for this message or null to indicate 'never expire'.
setFileFilter(FileFilter) - Method in class org.springframework.integration.adapter.file.FileSource
 
setFilenameFilter(FilenameFilter) - Method in class org.springframework.integration.adapter.file.FileSource
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.adapter.file.FileSourceAdapter
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.adapter.file.FileTargetAdapter
 
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
 
setHeader(MessageHeader) - Method in class org.springframework.integration.message.GenericMessage
 
setInitialDelay(long) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setInitialDelay(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setJmsTemplate(JmsTemplate) - Method in class org.springframework.integration.adapter.jms.JmsPollableSource
 
setJmsTemplate(JmsTemplate) - Method in class org.springframework.integration.adapter.jms.JmsTargetAdapter
 
setKeepAliveSeconds(int) - Method in class org.springframework.integration.endpoint.ConcurrencyPolicy
 
setMapper(MessageMapper) - Method in class org.springframework.integration.handler.AbstractMessageHandlerAdapter
 
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setMaxMessagesPerTask(int) - Method in class org.springframework.integration.dispatcher.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.MessageEndpointAnnotationPostProcessor
 
setMessageBus(MessageBus) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
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.adapter.jms.ChannelPublishingJmsListener
 
setMessageMapper(MessageMapper) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
Specify the MessageMapper to use when creating a message from the return value Object.
setMessagingTaskScheduler(MessagingTaskScheduler) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setMessagingTaskScheduler(MessagingTaskScheduler) - Method in class org.springframework.integration.bus.MessageBus
 
setMessagingTaskScheduler(MessagingTaskScheduler) - Method in class org.springframework.integration.dispatcher.DefaultMessageDispatcher
 
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 interface org.springframework.integration.channel.MessageChannel
Set the name of this channel.
setName(String) - Method in class org.springframework.integration.channel.SimpleChannel
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
 
setPayload(T) - Method in class org.springframework.integration.message.GenericMessage
 
setPeriod(long) - Method in class org.springframework.integration.adapter.PollingSourceAdapter
 
setPeriod(long) - Method in class org.springframework.integration.scheduling.PollingSchedule
Set the polling period.
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
 
setReceiveTimeout(long) - Method in class org.springframework.integration.dispatcher.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.dispatcher.DispatcherPolicy
Set the maximum number of retries upon rejection.
setReplyChannelName(String) - Method in class org.springframework.integration.message.MessageHeader
 
setReplyHandler(ReplyHandler) - Method in class org.springframework.integration.handler.ConcurrentHandler
 
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.dispatcher.DispatcherPolicy
Set the amount of time in milliseconds to wait between rejections.
setSchedule(Schedule) - Method in class org.springframework.integration.bus.Subscription
 
setSchedule(Schedule) - Method in class org.springframework.integration.dispatcher.DispatcherTask
 
setSecure(boolean) - Method in class org.springframework.integration.util.RandomGuidUidGenerator
Sets whether or not the generated random numbers should be secure.
setSendTimeout(long) - Method in class org.springframework.integration.adapter.AbstractSourceAdapter
 
setSendTimeout(long) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setSequenceNumber(int) - Method in class org.springframework.integration.message.MessageHeader
 
setSequenceSize(int) - Method in class org.springframework.integration.message.MessageHeader
 
setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
 
setShouldFailOnRejectionLimit(boolean) - Method in class org.springframework.integration.dispatcher.DispatcherPolicy
Specify whether an exception should be thrown when this dispatcher's DispatcherPolicy.rejectionLimit is reached.
setShouldTruncate(boolean) - Method in class org.springframework.integration.adapter.stream.ByteStreamSource
 
setShouldTruncate(boolean) - Method in class org.springframework.integration.adapter.stream.ByteStreamSourceAdapter
 
setShouldUseMapperOnInvocation(boolean) - Method in class org.springframework.integration.handler.DefaultMessageHandlerAdapter
Specify whether the handler method should use the MessageMapper when invoking the target method.
setSubscriberAnnotationType(Class<? extends Annotation>) - Method in class org.springframework.integration.config.SubscriberAnnotationPostProcessor
 
setSubscription(Subscription) - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
setThreadFactory(ThreadFactory) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setThreadNamePrefix(String) - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
setTimeout(long) - Method in class org.springframework.integration.adapter.jms.ChannelPublishingJmsListener
 
setTimeout(long) - Method in class org.springframework.integration.router.AbstractRoutingMessageHandler
Set the timeout for sending a message to the resolved channel.
setTimeUnit(TimeUnit) - Method in class org.springframework.integration.scheduling.PollingSchedule
 
setUidGenerator(UidGenerator) - Method in class org.springframework.integration.message.AbstractMessageMapper
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.file.config.FileSourceAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.file.config.FileTargetAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.jms.config.JmsSourceAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.adapter.jms.config.JmsTargetAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.file.config.FileSourceAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.file.config.FileTargetAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.jms.config.JmsSourceAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.adapter.jms.config.JmsTargetAdapterParser
 
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(DispatcherPolicy) - Constructor for class org.springframework.integration.channel.SimpleChannel
Create a channel with the default queue capacity and the specified dispatcher policy.
SimpleChannel() - Constructor for class org.springframework.integration.channel.SimpleChannel
Create a channel with the default queue capacity.
SimpleMessagingTaskScheduler - Class in org.springframework.integration.scheduling
An implementation of MessagingTaskScheduler that understands PollingSchedules.
SimpleMessagingTaskScheduler() - Constructor for class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
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 DocumentMessage.
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
 
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 - Class in org.springframework.integration.router
MessageHandler adapter for methods annotated with @Splitter.
SplitterMessageHandlerAdapter(Object, Method, Map<String, ?>) - Constructor for class org.springframework.integration.router.SplitterMessageHandlerAdapter
 
SplitterMessageHandlerCreator - Class in org.springframework.integration.handler.config
Creates a MessageHandler adapter for splitter methods.
SplitterMessageHandlerCreator() - Constructor for class org.springframework.integration.handler.config.SplitterMessageHandlerCreator
 
start() - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
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.dispatcher.DefaultMessageDispatcher
 
start() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
start() - Method in class org.springframework.integration.handler.ConcurrentHandler
 
start() - Method in class org.springframework.integration.scheduling.SimpleMessagingTaskScheduler
 
stderrAdapter() - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
Factory method that creates an adapter for stderr (System.err).
stdinAdapter(MessageChannel) - Static method in class org.springframework.integration.adapter.stream.CharacterStreamSourceAdapter
Factory method that creates an adapter for stdin (System.in).
stdoutAdapter() - Static method in class org.springframework.integration.adapter.stream.CharacterStreamTargetAdapter
Factory method that creates an adapter for stdout (System.out).
stop() - Method in class org.springframework.integration.adapter.jms.JmsMessageDrivenSourceAdapter
 
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.dispatcher.DefaultMessageDispatcher
 
stop() - Method in class org.springframework.integration.endpoint.DefaultMessageEndpoint
 
stop() - Method in class org.springframework.integration.handler.ConcurrentHandler
 
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.
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
 
Subscription - Class in org.springframework.integration.bus
Configuration metadata for activating a subscription.
Subscription() - Constructor for class org.springframework.integration.bus.Subscription
 
Subscription(MessageChannel) - Constructor for class org.springframework.integration.bus.Subscription
 
Subscription(String) - Constructor for class org.springframework.integration.bus.Subscription
 

T

Target<T> - Interface in org.springframework.integration.adapter
Interface for any external target that may receive data from an outgoing channel adapter.
TextFileMapper - Class in org.springframework.integration.adapter.file
A MessageMapper implementation for messages with a String payload.
TextFileMapper(File) - Constructor for class org.springframework.integration.adapter.file.TextFileMapper
 
toMessage(MessagingEvent<T>) - Method in class org.springframework.integration.adapter.event.MessagingEventMapper
 
toMessage(File) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
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 DocumentMessage with the given object as its payload.
toString() - Method in class org.springframework.integration.scheduling.PollingSchedule
 
toString() - Method in class org.springframework.integration.util.RandomGuid
Convert to the standard format for GUID (Useful for SQL Server UniqueIdentifiers, etc).

U

UidGenerator - Interface in org.springframework.integration.util
A strategy for generating ids to uniquely identify integration artifacts such as Messages.

V

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
 

W

writeToFile(File, T) - Method in class org.springframework.integration.adapter.file.AbstractFileMapper
 
writeToFile(File, byte[]) - Method in class org.springframework.integration.adapter.file.ByteArrayFileMapper
 
writeToFile(File, String) - Method in class org.springframework.integration.adapter.file.TextFileMapper
 

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