|
Spring Integration | |||||||||
PREV NEXT | FRAMES NO FRAMES |
MessageChannel
instances.MessageDispatcher
implementations.EntryListFilter
whose criteria can be
evaluated against each File in isolation.Status
implementations of
TwitterResponse
.JmsTemplate
.MailReceiver
implementations.MessageChannel
implementations providing common
properties such as the channel name.MessageProcessor
.OAuthAccessTokenBasedTwitterFactoryBean
.OAuthConfiguration
hosts the String values for authentication,
which we need to build up this instance, but the OAuthConfiguration
in turn needs references to the instances provided by
this FactoryBean
.
Transformer
implementations that modify the payload
of a Message
.MessageProcessor
for scripting implementations to extend.ScriptSource
.
AbstractChannelNameResolvingMessageRouter
to support router
implementations that always return a single channel name (or null).AbstractMessageRouter
to support router implementations that
always return a single MessageChannel
instance (or null).MessageChannel
that invokes the subscribed
handler(s)
by delegating to a MessageDispatcher
.TcpConnection
.Transformer
implementations.MessageSelector
implementations.XPathExpression
evaluation to determine channel names.XPathExpression
evaluates to true
XPathExpression
is equal to the valueToTestFor
.
EntryListFilter
implementation.EntryListFilter
that passes files only one time.AcceptOnceEntryFileListFilter
that is based on a bounded queue.
TcpListener
, this
method is called each time a new connection is made.
MessagingTemplate
to send downstream.
@Aggregator
annotation.ApplicationEvents
within messages.MessageHandler
that publishes each Message
it receives as
a MessagingEvent
.MessageSource
implementation that retrieves the current
value of a JMX attribute each time AttributePollingMessageSource.receive()
is invoked.ChannelResolver
implementation based on a Spring BeanFactory
.BeanFactoryChannelResolver
class.
BeanFactoryChannelResolver
class.
SqlParameterSourceFactory
which creates an SqlParameterSource
to
reference bean properties in its input.MessageSelector
.MessageSelector
supporting
mutliple namespaces.
MessageSelector
supporting a
single namespace.
MessageSelector
with no namespace
support.
MessageSelector
using the
provided XPathExpression
.
InputStream
.MessageHandler
that writes a byte array to an OutputStream
.ConfigAttribute
s for secured channel
send and receive operations.Messages
being sent-to and/or received-from a
MessageChannel
.ChannelInterceptor
with no-op method implementations so that
subclasses do not have to implement all of the interface's methods.ChannelSecurityInterceptor
.SecurityMetadataSource
implementation for secured MessageChannel
s.Messages
from one or more
QueueChannels
.MessageChannel
.BeanPostProcessor
that proxies MessageChannel
s to apply a ChannelSecurityInterceptor
.Readers
.MessageHandler
that writes characters to a Writer
.Messages
from this channel.
ControlBus
.
UUIDConverter.getUUID(Object)
.
MessageStore
.CorrelationStrategy
.javax.jms.QueueConnection
.
SqlParameterSource
.
javax.jms.QueueSession
.
Source
instance for payload
ConfigAttribute
s for secured channel
send and receive operations based on simple String values.HeaderMapper
implementation for HTTP.InboundRequestMapper
for inbound HttpServletRequests.JmsHeaderMapper
.MultipartFileReader
implementation that reads the MultipartFile
content directly into a new MultipartFile
instance that is not restricted
to the HTTP request scope.XmlPayloadConverter
.MessageHandler
that is capable of delaying the continuation of a
Message flow based on the presence of a delay header on an inbound Message
or a default delay value configured on this handler.RoundRobinLoadBalancingStrategy
LoadBalancingStrategy
.
SourceFactory
implementation which supports creation of a
DOMSource
from a Document
or String
payload.AbstractInboundRemoteFileSystemSychronizer.EntryAcknowledgmentStrategy
implementation
TaskExecutor
implementation that wraps an existing Executor
instance in order to catch any exceptions.Throwable
payload.MessageChannel
for
messages whose payload is an Exception..$[]^*+{}()\?
- establishTwitterObject(AccessToken) -
Method in class org.springframework.integration.twitter.oauth.AbstractOAuthAccessTokenBasedFactoryBean
-
- establishTwitterObject(AccessToken) -
Method in class org.springframework.integration.twitter.oauth.OAuthAccessTokenBasedTwitterFactoryBean
-
- ETX -
Static variable in class org.springframework.integration.ip.tcp.converter.ByteArrayStxEtxConverter
-
- evaluateExpression(Expression, Message<?>, Class<T>) -
Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(String, Object) -
Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(String, Object, Class<T>) -
Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression, Object) -
Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression, Object, Class<T>) -
Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateXPath(XPathExpression, Node) -
Method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
-
- EventDrivenConsumer - Class in org.springframework.integration.endpoint
- Message Endpoint that connects any
MessageHandler
implementation
to a SubscribableChannel
. - EventDrivenConsumer(SubscribableChannel, MessageHandler) -
Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
-
- EventDrivenDirectoryMonitor - Interface in org.springframework.integration.file.monitors
- Defines an interface for a component that reacts to file system events
- EventInboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventInboundChannelAdapterParser() -
Constructor for class org.springframework.integration.event.config.EventInboundChannelAdapterParser
-
- EventNamespaceHandler - Class in org.springframework.integration.event.config
- Namespace handler for Spring Integration's 'event' namespace.
- EventNamespaceHandler() -
Constructor for class org.springframework.integration.event.config.EventNamespaceHandler
-
- EventOutboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventOutboundChannelAdapterParser() -
Constructor for class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
-
- exchange(Message<?>) -
Method in class org.springframework.integration.gateway.RemotingInboundGatewaySupport
-
- exchange(Message<?>) -
Method in interface org.springframework.integration.gateway.RequestReplyExchanger
-
- execute(MessageGroupStore, MessageGroup) -
Method in interface org.springframework.integration.store.MessageGroupCallback
-
- execute(Runnable) -
Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
-
- executeScript(ScriptSource, Message<?>) -
Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- executeScript(ScriptSource, Message<?>) -
Method in class org.springframework.integration.handler.AbstractScriptExecutingMessageProcessor
- Subclasses must implement this method.
- executeUpdateQuery(Object, boolean) -
Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- ExecutorChannel - Class in org.springframework.integration.channel
- An implementation of
MessageChannel
that delegates to an instance of
UnicastingDispatcher
which in turn delegates all dispatching
invocations to an Executor
. - ExecutorChannel(Executor) -
Constructor for class org.springframework.integration.channel.ExecutorChannel
- Create an ExecutorChannel that delegates to the provided
Executor
when dispatching Messages.
- ExecutorChannel(Executor, LoadBalancingStrategy) -
Constructor for class org.springframework.integration.channel.ExecutorChannel
- Create an ExecutorChannel with a
LoadBalancingStrategy
that
delegates to the provided Executor
when dispatching Messages.
- EXPIRATION_DATE -
Static variable in class org.springframework.integration.MessageHeaders
-
- expireMessageGroups(long) -
Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- expireMessageGroups(long) -
Method in interface org.springframework.integration.store.MessageGroupStore
- Extract all expired groups (whose timestamp is older than the current time less the threshold provided) and call
each of the registered callbacks on them in turn.
- ExponentialMovingAverageCumulativeHistory - Class in org.springframework.integration.monitor
- Cumulative statistics for a series of real numbers with higher weight given to recent data but without storing any
history.
- ExponentialMovingAverageCumulativeHistory(int) -
Constructor for class org.springframework.integration.monitor.ExponentialMovingAverageCumulativeHistory
-
- ExponentialMovingAverageRateCumulativeHistory - Class in org.springframework.integration.monitor
- Cumulative statistics for rate with higher weight given to recent data but without storing any history.
- ExponentialMovingAverageRateCumulativeHistory(double, double, int) -
Constructor for class org.springframework.integration.monitor.ExponentialMovingAverageRateCumulativeHistory
-
- ExponentialMovingAverageRatioCumulativeHistory - Class in org.springframework.integration.monitor
- Cumulative statistics for success rate (ratio) with higher weight given to recent data but without storing any
history.
- ExponentialMovingAverageRatioCumulativeHistory(double, int) -
Constructor for class org.springframework.integration.monitor.ExponentialMovingAverageRatioCumulativeHistory
-
- EXPRESSION_ATTRIBUTE -
Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- ExpressionEvaluatingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy
implementation that evaluates an expression.- ExpressionEvaluatingCorrelationStrategy(String) -
Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- ExpressionEvaluatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
- A
MessageGroupProcessor
implementation that evaluates a SpEL expression. - ExpressionEvaluatingMessageGroupProcessor(String) -
Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- ExpressionEvaluatingMessageListProcessor - Class in org.springframework.integration.aggregator
- A base class for aggregators that evaluates a SpEL expression with the message list as the root object within the
evaluation context.
- ExpressionEvaluatingMessageListProcessor(String) -
Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
-
- ExpressionEvaluatingMessageProcessor<T> - Class in org.springframework.integration.handler
- A
MessageProcessor
implementation that evaluates a SpEL expression
with the Message itself as the root object within the evaluation context. - ExpressionEvaluatingMessageProcessor(String) -
Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
-
- ExpressionEvaluatingMessageProcessor(String, Class<T>) -
Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
- Create an
ExpressionEvaluatingMessageProcessor
for the given expression String.
- ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
- A
ReleaseStrategy
that evaluates an expression. - ExpressionEvaluatingReleaseStrategy(String) -
Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
-
- ExpressionEvaluatingRouter - Class in org.springframework.integration.router
- A Message Router implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingRouter(String) -
Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
-
- ExpressionEvaluatingSelector - Class in org.springframework.integration.filter
- A
MessageSelector
implementation that evaluates a SpEL expression. - ExpressionEvaluatingSelector(String) -
Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
-
- ExpressionEvaluatingSplitter - Class in org.springframework.integration.splitter
- A Message Splitter implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingSplitter(String) -
Constructor for class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
-
- ExpressionEvaluatingSqlParameterSourceFactory - Class in org.springframework.integration.jdbc
- An implementation of
SqlParameterSourceFactory
which creates an SqlParameterSource
that evaluates
Spring EL expressions. - ExpressionEvaluatingSqlParameterSourceFactory() -
Constructor for class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- ExpressionEvaluatingTransformer - Class in org.springframework.integration.transformer
- A Message Transformer implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingTransformer(String) -
Constructor for class org.springframework.integration.transformer.ExpressionEvaluatingTransformer
-
- ExpressionFactoryBean - Class in org.springframework.integration.config
- FactoryBean for creating Expression instances.
- ExpressionFactoryBean(String) -
Constructor for class org.springframework.integration.config.ExpressionFactoryBean
-
File
is detected.
File
MultipartFileReader
implementation that copies the MulitpartFile's
content to a new temporary File in the specified directory.FileCopyingMultipartFileReader
that creates temporary
Files in the default temporary directory.
FileCopyingMultipartFileReader
that creates temporary
Files in the given directory.
File
implementation of the EntryNamer
strategy.MessageSource
that creates messages from a file system directory.PriorityBlockingQueue
ordered with the passed in Comparator
The size of the queue used should be large enough to hold all the files in the input directory in order to sort
all of them, so restricting the size of the queue is mutually exclusive with ordering.
FileReadingMessageSource
that we continue to trust to do the job monitoring the filesystem once files are moved down
MessageHandler
implementation that writes the Message payload to a
file.EntryListFilter
that we're running against the @Filter
.MethodFilter
implementation that will always return
the same Method instance within a single-element list if it is
present in the candidate list.Roster
Message
instance pre-populated with
all of the headers copied from the provided message.
StatusUpdate
instances are used to drive status updates.
Presence
object from the inbound Message headers, if possible.
FTPClient
.FTPClient
instances.EntryNamer
for FTPFile
objectsAbstractInboundRemoteFileSystemSychronizer
MessageSource
implementation for FTPMessageHandler
implementation that sends files to an FTP server.XPathExpression.evaluateAsString(Node)
IntegrationObjectSupport.componentName
field.
AbstractConnectionFactory.setSingleUse(boolean)
was called with
true, a new connection is returned; otherwise a single connection is
reused for all requests while the connection remains open.
AbstractConnectionFactory.setSingleUse(boolean)
was called with
true, a new connection is returned; otherwise a single connection is
reused for all requests while the connection remains open.
next()
invocations.
MessageGroupStore.addMessageToGroup(Object, Message)
with this group id.
MessagingTemplate
for subclasses.
MessagingTemplate
access for subclasses.
AccessToken
for the first time.
AccessToken
for the first time.
Twitter
or AsyncTwitter
instances, we need to ask subclasses to call
us how to call AsyncTwitter.getOAuthRequestToken()
or Twitter.getOAuthRequestToken()
for us.This method
will never be evaluated as long as the OAuthConfiguration.accessToken
and OAuthConfiguration.accessTokenSecret
beans are not null.
SqlParameterSourceFactory
.
Message
.maxNumberOfFiles
elements from a directory listing.CorrelationStrategy
.MessageHeaders
to and from other
types of objects.MessageHeaders
of a Message
containing any entry
or multiple that match?MessageHandler
implementation that executes HTTP requests by delegating
to a RestTemplate
instance.Controller
interface to be used with a DispatcherServlet front
controller.MailReceiver
implementation for receiving mail messages from a
mail server that supports the IMAP protocol.InboundMessageMapper
implementation that maps incoming JSON messages to a Message
with the specified payload type.Status
that are 'replies' or 'mentions' to some other tweet.Message
.HttpServletRequest
to a Message.MessageSource
lets Spring Integration consume a given account's timeline
as messages.TaskScheduler
and ConversionService
instances.FactoryBean
method.
DataSource
from which the DB Connection can be obtained and the select query to
execute to retrieve new rows.
JdbcOperations
instance to use for query execution and the select query to execute to
retrieve new rows.
MessageStore
using a relational database via JDBC.MessageStore
with all mandatory properties.
JdbcMessageStore
.DataSource
from which the DB Connection can be
obtained and the select query to execute to retrieve new rows.
JdbcOperations
instance to use for query
execution and the select query to execute to retrieve new rows.
JdbcPollingChannelAdapter
.MessageChannel
implementation that is actually backed by a JMS
Destination.true
if it was
successful, false
otherwise.
true
if it was
successful, false
otherwise.
Messages
.MessageSource
implementation that delegates to a
MailReceiver
to poll a mailbox.MessageHandler
implementation for sending mail.Message
to a String.ChannelResolver
implementation that resolves MessageChannel
instances by matching the channel name against keys within a Map.MapBasedChannelResolver.setChannelMap(Map)
.
ChannelResolver
that uses the provided Map.
MetadataPersister
interface suitable for the use cases where it's assured that component only needs ephemeral metadata.Map
.AbstractTransformer
that delegates to an OXM Marshaller
.MarshallingWebServiceInboundGateway
.
MarshallingWebServiceInboundGateway
with the given marshaller.
MarshallingWebServiceInboundGateway
with the given marshaller and unmarshaller.
ReleaseStrategy
that releases only the first n
messages, where n
is a threshold.MessageSelector
.MessageSelector
.
BlockingQueue
that is backed by a MessageGroupStore
.MessageGroup
instances in a
MessageGroupStore
.MessageHandler
implementation that invokes a chain of
MessageHandler instances in order.Message
.MessageChannel
.ErrorHandler
implementation that sends an ErrorMessage
to a
MessageChannel
.MethodInterceptor
that publishes Messages to a channel.ChannelInterceptor
that
delegates to a list of MessageSelectors
to decide
whether a Message
should be accepted on the MessageChannel
.Message
on the receipt of a new File
Comparator
implementation based on the 'sequence number'
property of a Message's
header.Messages
that can be polled.ChannelInterceptor
which invokes a Transformer
when either sending-to or receiving-from a channel.MessageHandler
that delegates to a
Transformer
instance to modify the received Message
and sends the result to its output channel.MessageTransformingHandler
instance that delegates to
the provided Transformer
.
BeanPostProcessor
implementation that processes method-level
messaging annotations such as @Transformer, @Splitter, @Router, and @Filter.ApplicationEvent
that wraps a Message
.MessageChannel
s for sending, receiving, or request-reply operations.MessageChannel
s.PublisherMetadataSource
implementation that retrieves the channel
name and expression strings from an annotation.CorrelationStrategy
implementation that works as an adapter to another bean.MessageHandler
that invokes the specified method on the provided object.MessageSource
implementation that invokes a no-argument method so
that its return value may be sent to a channel.ReleaseStrategy
that invokes a method on a plain old Java object.MessageSelector
.Message
matcher creation.FileAdditionListener
for a given #directory
MessageHandler
implementation that maps a Message into
a UDP datagram packet and sends that to the specified multicast address
(224.0.0.0 to 239.255.255.255) and port.HttpMessageConverter
implementation that delegates to an instance of
XmlAwareFormHttpMessageConverter
while adding the capability to read
multipart/form-data
content in an HTTP request.MultipartFile
content.NotificationListener
implementation that will send Messages
containing the JMX Notification
instances as their payloads.AsyncTwitter
and an Twitter
instance.toString()
method.FTPClient
impl *after* the
implementation's SocketClient.connect(String)
method's been called but before any
action's been taken.
MessageHandler
implementation for invoking JMX operations based on
the Message sent to its AbstractMessageHandler.handleMessage(Message)
method.OutboundMessageMapper
implementation the converts a Message
to a JSON string representation.Message
to an Object.EntryNamer
)
against a regular expression (an instance of Pattern
)Message
equal to a given value or is matching
a given matcher?HandlerMethodResolver
that matches the payload
type of the Message against the expected type of its candidate methods.MessageChannel
based on the
Message's
payload type.MessageSelector
implementation that checks the type of the
Message
payload.MessageHandler
implementation
to a PollableChannel
.MailReceiver
implementation that polls a mail server using the
POP3 protocol.getClient()
.
MessageSelector
,
send it to the secondary target.
Comparator
.MetadataPersister
that knows how to write metadata
to a Properties
instance.MessagePublishingInterceptor
to any
methods containing the provided annotations.Publisher
annotation.Executor
to invoke the handlers.
Messages
that are not accepted by the provided selector.
SftpSessionPool
) that has an
implementation of Queued*SessionPool (QueuedSftpSessionPool
) - was
taken pretty directly from the incredibly good Spring IntegrationFTP adapter.MultipartFile
content.
Message
converting and returning it as
a Spring Integration Message
.
MessageGroupStore.expireMessageGroups(long)
.
ReleaseStrategy
.TcpListener
, this
method is called each time a connection is closed.
QueueChannel
that delegates to a
SynchronousQueue
internally.MessageChannel
,
via this template's ChannelResolver
if available.
Result
possibly taking into account the
provided message payload instance.Document
from a Result
payload.Result
to an instance of String
Supports StringResult
and DOMResult
LoadBalancingStrategy
.@Router
.timeout
provided.
ScheduledFuture
instance we get when we schedule our AbstractInboundRemoteFileSystemSychronizer.SynchronizeTask
ChannelSecurityInterceptor
to control send and receive access, and creates a bean post-processor to apply the
interceptor to MessageChannel
s
whose names match the specified patterns.Message
to this channel.
ReleaseStrategy
that simply compares the
current size of the message list to the expected 'sequenceSize'.HttpMessageConverter
implementation for Serializable
instances.SerializingHttpMessageConverter
.
@ServiceActivator
.ServiceActivatingHandler
instances.SourceFactory
.
ResultFactory
and SourceFactory
should always
be used, even for directly supported payloads such as String
and Document
.
BeanFactory
necessary to look up a
'targetBeanName'
if specified.
@beanName
in the expression.
XPathExpression
to test value should be case sensitive.
ChannelResolver
that is to be used to resolve
MessageChannel
references for this template.
ChannelResolver
strategy to use.
FTPClient.ACTIVE_LOCAL_CONNECTION_MODE
(default) Only local
modes are supported.
FtpClientPool
that holds references to FTPClient
instances
ConversionService
to use when trying to convert to
one of this channel's supported datatypes for a Message whose payload
does not already match.
XmlPayloadConverter
to use when converting a Message payload prior to XPath evaluation.
DataSource
to use when interacting with the database.
DestinationResolver
to use when resolving either a
'requestDestinationName' or 'replyDestinationName' value.
ErrorHandler
strategy for handling Exceptions that
occur downstream from this channel.
ResponseErrorHandler
for the underlying RestTemplate
.
Errors
in the model, in the case that message handling fails.
XPathEvaluationType
.
InboundMessageMapper
for creating a reply Message from
an Exception that occurs downstream from this gateway.
ApplicationContext
is closed).
MessageConverter
has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter)
method.
MessageConverter
has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter)
method.
MessageHandler
throws an Exception.
FileNameGenerator
strategy to use when generating
the destination file's name.
EntryListFilter
.
NotificationFilter
to be passed to the server
when registering this listener.
HeaderMapper
to use when mapping between HTTP headers and MessageHeaders.
JmsHeaderMapper
implementation to use when
converting between JMS Messages and Spring Integration Messages.
JmsHeaderMapper
implementation for mapping the
Spring Integration Message Headers to/from JMS Message properties.
HttpMethod
for requests.
Session
will be created with these properties (and the JavaMailAuthenticator if provided).
JdbcOperations
to use when interacting with the database.
LoadBalancingStrategy
for this dispatcher.
LobHandler
that is used to create and unpack large objects in SQL queries.
AbstractMailReceiver.receive()
.
MessageConverter
that is to be used to convert
between Messages and objects for this template.
MessageConverter
strategy to use for converting
between Spring Integration Messages and JMS Messages.
MessageConverter
implementation to use when
converting between JMS Messages and Spring Integration Messages.
MessageConverter
strategy to use for converting the
Spring Integration request Message into a JMS Message and for converting
the JMS reply Messages back into Spring Integration Messages.
HttpMessageConverter
s to be used by the underlying RestTemplate
.
Presence
MessageStore
that should be used to store Messages
while awaiting the delay.
MultipartFileReader
to use when reading MultipartFile
content.
MultipartResolver
to use when checking requests.
NodeMapper
to use for generating the result object.
ObjectName
.
MessageChannel
where Messages should be sent.
Properties
instance in play than we can simply use that one.
HttpRequestHandlingEndpointSupport.setExtractReplyPayload(boolean)
is false
).
OutboundMessageMapper
for mapping to objects from
any reply Messages received in receive or sendAndReceive operations.
ClientHttpRequestFactory
for the underlying RestTemplate
.
InboundMessageMapper
for creating request Messages
from any object passed in a send or sendAndReceive operation.
RecursiveLeafOnlyDirectoryScanner
Session
.
FolderClosedException
while waiting for messages.
null
values, such as might be returned from an expression evaluation,
should be skipped.
ErrorMessage
should be extracted and thrown from a send-and-receive operation.
MessageRejectedException
when its selector does not accept a
Message.
MulticastSocket
time to live property.
WebBindingInitializer
to be invoked prior
to the request binding process.
ChannelSftp.LsEntry
instanceMessageSource
implementation for SFTPSftpSession
just as there are many ways to SSH into a remote system.SftpSession
instances.SftpSession
since they're stateful
and might be in use while another run happens.MessageStore
and group id.InboundMessageMapper
and
OutboundMessageMapper
strategy interfaces that maps directly to and
from the Message payload instance.MessageStore
and MessageGroupStore
.MultipartFileReader
implementation that does not maintain metadata from
the original MultipartFile
instance.PublisherMetadataSource
that allows for
configuration of a single channel name, payload expression, and
array of header key=value expressions.EntryListFilter
and produces an object that can field just one argument instea of an arraySource
using a SourceFactory
.Source
possibly taking into account
the provided message payload instance.MessageSource
to a MessageChannel
.@Splitter
.SqlParameterSource
for use in update operations.HandlerMethodResolver
that always returns the
same Method instance.StatusUpdate
instanceSourceFactory
implementation which supports creation of a
StringSource
from either a Document
or String
payloadMessageSelector
that tests if a provided value supports
payloads of type Document
or String
.XPathExpression
.
MessageHandler
as a subscriber to this channel.
Socket
and SocketChannel
that
sends Message
objects by converting the payload
and streaming it to the destination.TcpConnection
TcpConnection
to a Message
.TcpNetConnection
s.Socket
.TcpNetConnection
s using
a ServerSocket
.TcpNioConnection
s.SocketChannel
.TcpNioConnection
s using
a ServerSocketChannel
.ReleaseStrategy
that releases all messages if any of the following is true:
The sequence is complete (if there is one).Message
with payload Presence
URLName
, where the
password has been protected.
Message
.@Transformer
.MessageSelector
that accepts Messages
that are
not yet expired.MessageDispatcher
that will attempt to send a
Message
to at most one of its handlers.MessageHandler
implementation that maps a Message into
a UDP datagram packet and sends that to the specified host and port.Transformer
that delegates to an OXM
Unmarshaller
.MessageHandler
from the subscribers of this channel.
MultipartFile
implementation that represents an uploaded File.ChannelInterceptor
that publishes a copy of the intercepted message
to a secondary target while still sending the original message to the main channel.MessageSelector
.
MessageSelector
.
Message
instance with the provided payload.
Document
instancesXMPPConnection
object.Message
objects
that handle XMPP events.OutboundMessageMapper
.XmppConnectionFactory
and then emit Message
s when a particular event happens to the logged in users Roster
.XPathExpression
to split a
Document
or String
payload into a NodeList
.XPathExpression.evaluateAsNodeList(Node)
which returns zero or more
nodes in conjunction with an instance of NodeMapper
to produce zero
or more channel names.XPathExpression.evaluateAsString(Node)
to extract a channel name.XPathTransformer
that will create an XPath expression from the given String
to be evaluated against converted inbound Message payloads.
XPathTransformer
that will evaluate the given XPathExpression
against converted inbound Message payloads.
Transformer
instance used for XSL transformation.Source
, Document
, or String
.
|
Spring Integration | |||||||||
PREV NEXT | FRAMES NO FRAMES |