Package | Description |
---|---|
org.springframework.integration.aggregator |
Provides classes related to message aggregation.
|
org.springframework.integration.amqp.channel |
Provides classes related to AMQP-backed channels.
|
org.springframework.integration.amqp.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.amqp.outbound |
Provides classes supporting outbound endpoints.
|
org.springframework.integration.channel |
Provides classes representing various channel types.
|
org.springframework.integration.endpoint |
Provides core classes related to Endpoints.
|
org.springframework.integration.event.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.event.outbound |
Provides classes supporting outbound endpoints.
|
org.springframework.integration.feed.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.file |
Base package for File support.
|
org.springframework.integration.file.remote.gateway |
Provides classes supporting remote file gateways.
|
org.springframework.integration.file.remote.handler |
Provides classes supporting remote file message handlers.
|
org.springframework.integration.file.remote.synchronizer |
Provides classes supporting the synchronization of remote and
local file directories.
|
org.springframework.integration.file.tail |
Classes used for tailing file system files.
|
org.springframework.integration.filter |
Provides classes supporting the filter pattern.
|
org.springframework.integration.ftp.gateway |
Provides classes supporting FTP gateways.
|
org.springframework.integration.ftp.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.gateway |
Provides classes supporting messaging gateways.
|
org.springframework.integration.handler |
Provides classes implementing various types of message handler.
|
org.springframework.integration.handler.advice |
Provides classes that are used to advise
MessageHandler s with
cross-cutting concerns. |
org.springframework.integration.http.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.http.outbound |
Provides classes supporting outbound endpoints.
|
org.springframework.integration.ip |
Base package for IP (TCP/UDP) Support.
|
org.springframework.integration.ip.tcp |
Base package for TCP Support.
|
org.springframework.integration.ip.tcp.connection |
All things related to tcp connections - client and
server factories; listener and sender interfaces.
|
org.springframework.integration.ip.udp |
Base package for UDP support.
|
org.springframework.integration.jdbc |
Root package of the Spring Integration JDBC module, which contains various
JDBC and Stored Procedure/Function supporting components.
|
org.springframework.integration.jms |
Base package for JMS Support.
|
org.springframework.integration.jmx |
Base package for JMX support.
|
org.springframework.integration.jpa.inbound |
Provides inbound Spring Integration Jpa components.
|
org.springframework.integration.jpa.outbound |
Provides Spring Integration components for doing outbound operations.
|
org.springframework.integration.json |
Provides classes supporting JSON in Spring Integration.
|
org.springframework.integration.mail |
Base package for Mail support.
|
org.springframework.integration.mongodb.inbound |
Provides classes related to the Mongo inbound channel adapters
|
org.springframework.integration.mongodb.outbound |
Provides classes related to the Mongo outbound channel adapters
|
org.springframework.integration.redis.channel |
Provides classes related to Redis-backed channels.
|
org.springframework.integration.redis.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.redis.outbound |
Provides classes supporting outbound endpoints.
|
org.springframework.integration.rmi |
Base package for RMI support.
|
org.springframework.integration.router |
Provides classes supporting the router pattern.
|
org.springframework.integration.sftp.gateway |
Provides classes supporting SFTP gateways.
|
org.springframework.integration.sftp.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.splitter |
Provides classes supporting the splitter pattern.
|
org.springframework.integration.stream |
Base package for stream support.
|
org.springframework.integration.syslog.inbound |
Provides classes for inbound endpoints.
|
org.springframework.integration.transaction |
Provides classes supporting the use of transactions and
pseudo transactions in Spring Integration applications.
|
org.springframework.integration.transformer |
Contains core-implementation of various Transformers which includes Enrichers
and Filters.
|
org.springframework.integration.twitter.inbound |
Provides inbound Twitter components.
|
org.springframework.integration.twitter.outbound |
Provides outbound Twitter components.
|
org.springframework.integration.ws |
Provides several inbound and outbound Web Service components.
|
org.springframework.integration.xml.router |
Provides XML message routers.
|
org.springframework.integration.xml.splitter |
Provides implementations of
AbstractMessageSplitter . |
org.springframework.integration.xml.transformer |
Provides Transformer and Enricher implementations.
|
org.springframework.integration.xmpp.core |
Provides classes shared across all XMPP components.
|
org.springframework.integration.xmpp.inbound |
Provides XMPP inbound Endpoint implementations that extend
AbstractXmppConnectionAwareEndpoint . |
org.springframework.integration.xmpp.outbound |
Provides XMPP outbound Messagehandler implementations.These components extend
AbstractXmppConnectionAwareMessageHandler |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCorrelatingMessageHandler
Abstract Message handler that holds a buffer of correlated messages in a
MessageStore . |
class |
AggregatingMessageHandler
Aggregator specific implementation of
AbstractCorrelatingMessageHandler . |
class |
CorrelatingMessageBarrier
This Endpoint serves as a barrier for messages that should not be processed yet.
|
class |
ResequencingMessageHandler
Resequencer specific implementation of
AbstractCorrelatingMessageHandler . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAmqpChannel |
class |
PointToPointSubscribableAmqpChannel |
class |
PollableAmqpChannel
A
PollableChannel implementation that is backed by an AMQP Queue. |
class |
PublishSubscribeAmqpChannel |
Modifier and Type | Class and Description |
---|---|
class |
AmqpInboundChannelAdapter
Adapter that receives Messages from an AMQP Queue, converts them into
Spring Integration Messages, and sends the results to a Message Channel.
|
class |
AmqpInboundGateway
Adapter that receives Messages from an AMQP Queue, converts them into
Spring Integration Messages, and sends the results to a Message Channel.
|
Modifier and Type | Class and Description |
---|---|
class |
AmqpOutboundEndpoint
Adapter that converts and sends Messages to an AMQP Exchange.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMessageChannel
Base class for
MessageChannel implementations providing common
properties such as the channel name. |
class |
AbstractPollableChannel
Base class for all pollable channels.
|
class |
AbstractSubscribableChannel
Base implementation of
MessageChannel that invokes the subscribed
handler(s) by delegating to a MessageDispatcher . |
class |
DefaultHeaderChannelRegistry
Converts a channel to a name, retaining a reference to the channel keyed by the name.
|
class |
DirectChannel
A channel that invokes a single subscriber for each sent Message.
|
class |
ExecutorChannel
An implementation of
MessageChannel that delegates to an instance of
UnicastingDispatcher which in turn delegates all dispatching
invocations to an Executor . |
class |
PriorityChannel
A message channel that prioritizes messages based on a
Comparator . |
class |
PublishSubscribeChannel
A channel that sends Messages to each of its subscribers.
|
class |
QueueChannel
Simple implementation of a message channel.
|
class |
RendezvousChannel
A zero-capacity version of
QueueChannel that delegates to a
SynchronousQueue internally. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEndpoint
The base class for Message Endpoint implementations.
|
class |
AbstractPollingEndpoint |
class |
EventDrivenConsumer
Message Endpoint that connects any
MessageHandler implementation to a SubscribableChannel . |
class |
ExpressionMessageProducerSupport
A
MessageProducerSupport sub-class that provides ExpressionMessageProducerSupport.payloadExpression
evaluation with result as a payload for Message to send. |
class |
MessageProducerSupport
A support class for producer endpoints that provides a setter for the
output channel and a convenience method for sending Messages.
|
class |
PollingConsumer
Message Endpoint that connects any
MessageHandler implementation
to a PollableChannel . |
class |
SourcePollingChannelAdapter
A Channel Adapter implementation for connecting a
MessageSource to a MessageChannel . |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationEventListeningMessageProducer
An inbound Channel Adapter that implements
ApplicationListener and
passes Spring ApplicationEvents within messages. |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationEventPublishingMessageHandler
|
Modifier and Type | Class and Description |
---|---|
class |
FeedEntryMessageSource
This implementation of
MessageSource will produce individual
SyndEntry s for a feed identified with the 'feedUrl' attribute. |
Modifier and Type | Class and Description |
---|---|
class |
FileReadingMessageSource
MessageSource that creates messages from a file system directory. |
class |
FileWritingMessageHandler
A
MessageHandler implementation that writes the Message payload to a
file. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRemoteFileOutboundGateway<F>
Base class for Outbound Gateways that perform remote file operations.
|
Modifier and Type | Class and Description |
---|---|
class |
FileTransferringMessageHandler<F>
A
MessageHandler implementation that transfers files to a remote server. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractInboundFileSynchronizingMessageSource<F>
Factors out the common logic between the FTP and SFTP adapters.
|
Modifier and Type | Class and Description |
---|---|
class |
ApacheCommonsFileTailingMessageProducer
File tailer that delegates to the Apache Commons Tailer.
|
class |
FileTailingMessageProducerSupport
Base class for file tailing inbound adapters.
|
class |
OSDelegatingFileTailingMessageProducer
A file tailing message producer that delegates to the OS tail program.
|
Modifier and Type | Class and Description |
---|---|
class |
MessageFilter
Message Handler that delegates to a
MessageSelector . |
Modifier and Type | Class and Description |
---|---|
class |
FtpOutboundGateway
Outbound Gateway for performing remote file operations via FTP/FTPS.
|
Modifier and Type | Class and Description |
---|---|
class |
FtpInboundFileSynchronizingMessageSource
A
MessageSource implementation for FTP. |
Modifier and Type | Class and Description |
---|---|
class |
GatewayProxyFactoryBean
Generates a proxy for the provided service interface to enable interaction
with messaging components without application code being aware of them allowing
for POJO-style interaction.
|
class |
MessagingGatewaySupport
A convenient base class for connecting application code to
MessageChannel s for sending, receiving, or request-reply operations. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMessageHandler
Base class for MessageHandler implementations that provides basic validation
and error handling capabilities.
|
class |
AbstractReplyProducingMessageHandler
Base class for MessageHandlers that are capable of producing replies.
|
class |
AbstractReplyProducingPostProcessingMessageHandler |
class |
BridgeHandler
A simple MessageHandler implementation that passes the request Message
directly to the output channel without modifying it.
|
class |
DelayHandler
A
MessageHandler that is capable of delaying the continuation of a
Message flow based on the result of evaluation delayExpression on an inbound Message
or a default delay value configured on this handler. |
class |
ExpressionEvaluatingMessageHandler
A
MessageHandler that evaluates
the provided Expression expecting a void return. |
class |
LoggingHandler
MessageHandler implementation that simply logs the Message or its payload depending on the value of the
'shouldLogFullMessage' property.
|
class |
MessageHandlerChain
A composite
MessageHandler implementation that invokes a chain of
MessageHandler instances in order. |
class |
MethodInvokingMessageHandler
A
MessageHandler that invokes the specified method on the provided object. |
class |
ServiceActivatingHandler |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRequestHandlerAdvice
Base class for
MessageHandler advice classes. |
class |
ExpressionEvaluatingRequestHandlerAdvice
Used to advise
MessageHandler s. |
class |
RequestHandlerCircuitBreakerAdvice
A circuit breaker that stops calling a failing service after threshold
failures, until halfOpenAfter milliseconds has elapsed.
|
class |
RequestHandlerRetryAdvice
Uses spring-retry to perform stateless or stateful retry.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpRequestHandlingController
Inbound HTTP endpoint that implements Spring's
Controller interface to be used with a DispatcherServlet front
controller. |
class |
HttpRequestHandlingEndpointSupport
Base class for HTTP request handling endpoints.
|
class |
HttpRequestHandlingMessagingGateway
Inbound Messaging Gateway that handles HTTP Requests.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpRequestExecutingMessageHandler
A
MessageHandler implementation that executes HTTP requests by delegating
to a RestTemplate instance. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractInternetProtocolReceivingChannelAdapter
Base class for inbound TCP/UDP Channel Adapters.
|
class |
AbstractInternetProtocolSendingMessageHandler
Base class for all TCP/UDP MessageHandlers.
|
Modifier and Type | Class and Description |
---|---|
class |
TcpInboundGateway
Inbound Gateway using a server connection factory - threading is controlled by the
factory.
|
class |
TcpOutboundGateway
TCP outbound gateway that uses a client connection factory.
|
class |
TcpReceivingChannelAdapter
Tcp inbound channel adapter using a TcpConnection to
receive data - if the connection factory is a server
factory, this Listener owns the connections.
|
class |
TcpSendingMessageHandler
Tcp outbound channel adapter using a TcpConnection to
send data - if the connection factory is a server
factory, the TcpListener owns the connections.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractClientConnectionFactory
Abstract class for client connection factories; client connection factories
establish outgoing connections.
|
class |
AbstractConnectionFactory
Base class for all connection factories.
|
class |
AbstractServerConnectionFactory
Base class for all server connection factories.
|
class |
CachingClientConnectionFactory |
class |
FailoverClientConnectionFactory
Given a list of connection factories, serves up
TcpConnection s
that can iterate over a connection from each factory until the write
succeeds or the list is exhausted. |
class |
TcpConnectionEventListeningMessageProducer
MessageProducer that produces Messages with @link TcpConnectionEvent
payloads. |
class |
TcpNetClientConnectionFactory
A client connection factory that creates
TcpNetConnection s. |
class |
TcpNetServerConnectionFactory
Implements a server connection factory that produces
TcpNetConnection s using
a ServerSocket . |
class |
TcpNioClientConnectionFactory
A client connection factory that creates
TcpNioConnection s. |
class |
TcpNioServerConnectionFactory
/**
Implements a server connection factory that produces
TcpNioConnection s using
a ServerSocketChannel . |
Modifier and Type | Class and Description |
---|---|
class |
MulticastReceivingChannelAdapter
Channel adapter that joins a multicast group and receives incoming packets and
sends them to an output channel.
|
class |
MulticastSendingMessageHandler
A
MessageHandler implementation that maps a Message into
a UDP datagram packet and sends that to the specified multicast address
(224.0.0.0 to 239.255.255.255) and port. |
class |
UnicastReceivingChannelAdapter
A channel adapter to receive incoming UDP packets.
|
class |
UnicastSendingMessageHandler
A
MessageHandler implementation that maps a Message into
a UDP datagram packet and sends that to the specified host and port. |
Modifier and Type | Class and Description |
---|---|
class |
JdbcMessageHandler
A message handler that executes an SQL update.
|
class |
JdbcOutboundGateway |
class |
JdbcPollingChannelAdapter
A polling channel adapter that creates messages from the payload returned by
executing a select query.
|
class |
StoredProcMessageHandler
A message handler that executes Stored Procedures for update purposes.
|
class |
StoredProcOutboundGateway |
class |
StoredProcPollingChannelAdapter
A polling channel adapter that creates messages from the payload returned by
executing a stored procedure or Sql function.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractJmsChannel |
class |
JmsDestinationPollingSource
A source for receiving JMS Messages with a polling listener.
|
class |
JmsMessageDrivenEndpoint
A message-driven endpoint that receive JMS messages, converts them into
Spring Integration Messages, and then sends the result to a channel.
|
class |
JmsOutboundGateway
An outbound Messaging Gateway for request/reply JMS.
|
class |
JmsSendingMessageHandler
A MessageConsumer that sends the converted Message payload within a JMS Message.
|
class |
PollableJmsChannel |
class |
SubscribableJmsChannel |
Modifier and Type | Class and Description |
---|---|
class |
NotificationListeningMessageProducer
A JMX
NotificationListener implementation that will send Messages
containing the JMX Notification instances as their payloads. |
class |
NotificationPublishingMessageHandler |
class |
OperationInvokingMessageHandler
A
MessageHandler implementation for invoking JMX operations based on
the Message sent to its AbstractMessageHandler.handleMessage(Message) method. |
Modifier and Type | Class and Description |
---|---|
class |
JpaPollingChannelAdapter
Polling message source that produces messages from the result of the provided:
entityClass
JpQl Select Query
Sql Native Query
JpQl Named Query
Sql Native Named Query
After the objects have been polled, it also possibly to either:
executes an update after the select possibly to updated the state of selected records
executes an update (per retrieved object or for the entire payload)
delete the retrieved object
|
Modifier and Type | Class and Description |
---|---|
class |
JpaOutboundGateway
The Jpa Outbound Gateway will allow you to make outbound operations to either:
submit (insert, delete) data to a database using JPA
retrieve (select) data from a database
Depending on the selected
OutboundGatewayType , the outbound gateway
will use either the JpaExecutor 's poll method or its
executeOutboundJpaOperation method. |
Modifier and Type | Class and Description |
---|---|
class |
JsonToObjectTransformer
Transformer implementation that converts a JSON string payload into an instance of the provided target Class.
|
class |
ObjectToJsonTransformer
Transformer implementation that converts a payload instance into a JSON string representation.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMailReceiver
Base class for
MailReceiver implementations. |
class |
ImapIdleChannelAdapter
An event-driven Channel Adapter that receives mail messages from a mail
server that supports the IMAP "idle" command (see RFC 2177).
|
class |
ImapMailReceiver
A
MailReceiver implementation for receiving mail messages from a
mail server that supports the IMAP protocol. |
class |
MailSendingMessageHandler
A
MessageHandler implementation for sending mail. |
class |
Pop3MailReceiver
A
MailReceiver implementation that polls a mail server using the
POP3 protocol. |
Modifier and Type | Class and Description |
---|---|
class |
MongoDbMessageSource
An instance of
MessageSource which returns a Message with a payload
which is the result of execution of a Query . |
Modifier and Type | Class and Description |
---|---|
class |
MongoDbStoringMessageHandler
Implementation of
MessageHandler which writes Message payload into a MongoDb collection
identified by evaluation of the MongoDbStoringMessageHandler.collectionNameExpression . |
Modifier and Type | Class and Description |
---|---|
class |
SubscribableRedisChannel |
Modifier and Type | Class and Description |
---|---|
class |
RedisInboundChannelAdapter |
class |
RedisQueueMessageDrivenEndpoint |
class |
RedisStoreMessageSource
Inbound channel adapter which returns a Message representing a view into
a Redis store.
|
Modifier and Type | Class and Description |
---|---|
class |
RedisPublishingMessageHandler |
class |
RedisQueueOutboundChannelAdapter |
class |
RedisStoreWritingMessageHandler
Implementation of
MessageHandler which writes Message data into a Redis store
identified by a key String . |
Modifier and Type | Class and Description |
---|---|
class |
RmiInboundGateway
An inbound Messaging Gateway for RMI-based remoting.
|
class |
RmiOutboundGateway
An outbound Messaging Gateway for RMI-based remoting.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMappingMessageRouter
Base class for all Message Routers that support mapping from arbitrary String values
to Message Channel names.
|
class |
AbstractMessageRouter
Base class for all Message Routers.
|
class |
ErrorMessageExceptionTypeRouter
A Message Router that resolves the target
MessageChannel for
messages whose payload is an Exception. |
class |
ExpressionEvaluatingRouter
A Message Router implementation that evaluates the specified SpEL
expression.
|
class |
HeaderValueRouter
A Message Router that resolves the MessageChannel from a header value.
|
class |
MethodInvokingRouter
A Message Router that invokes the specified method on the given object.
|
class |
PayloadTypeRouter
A Message Router that resolves the
MessageChannel based on the
Message's payload type. |
class |
RecipientListRouter
|
Modifier and Type | Class and Description |
---|---|
class |
SftpOutboundGateway
Outbound Gateway for performing remote file operations via SFTP.
|
Modifier and Type | Class and Description |
---|---|
class |
SftpInboundFileSynchronizingMessageSource
A
MessageSource implementation for SFTP
that delegates to an InboundFileSynchronizer. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMessageSplitter
Base class for Message-splitting handlers.
|
class |
DefaultMessageSplitter
The default Message Splitter implementation.
|
class |
ExpressionEvaluatingSplitter
A Message Splitter implementation that evaluates the specified SpEL
expression.
|
class |
MethodInvokingSplitter
A Message Splitter implementation that invokes the specified method
on the given object.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteStreamWritingMessageHandler
A
MessageHandler that writes a byte array to an OutputStream . |
class |
CharacterStreamReadingMessageSource
A pollable source for
Readers . |
class |
CharacterStreamWritingMessageHandler
A
MessageHandler that writes characters to a Writer . |
Modifier and Type | Class and Description |
---|---|
class |
SyslogReceivingChannelAdapterSupport
Base support class for inbound channel adapters.
|
class |
TcpSyslogReceivingChannelAdapter
TCP implementation of a syslog inbound channel adapter.
|
class |
UdpSyslogReceivingChannelAdapter
UDP implementation of a syslog inbound channel adapter.
|
Modifier and Type | Class and Description |
---|---|
class |
ExpressionEvaluatingTransactionSynchronizationProcessor
This implementation of
TransactionSynchronizationFactory
allows you to configure SpEL expressions, with their execution being coordinated
(synchronized) with a transaction - see TransactionSynchronization . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPayloadTransformer<T,U>
A base class for
Transformer implementations that modify the payload
of a Message . |
class |
AbstractTransformer
A base class for
Transformer implementations. |
class |
ClaimCheckInTransformer
Transformer that stores a Message and returns a new Message whose payload
is the id of the stored Message.
|
class |
ClaimCheckOutTransformer
Transformer that accepts a Message whose payload is a UUID and retrieves the Message associated
with that id from a MessageStore if available.
|
class |
ContentEnricher
Content Enricher is a Message Transformer that can augment a message's payload
with either static values or by optionally invoking a downstream message flow
via its request channel and then applying values from the reply Message to the
original payload.
|
class |
MapToObjectTransformer
Will transform Map to an instance of Object.
|
class |
MessageTransformingHandler
A reply-producing
MessageHandler that delegates to a
Transformer instance to modify the received Message
and sends the result to its output channel. |
class |
ObjectToMapTransformer
Will transform an object graph into a Map.
|
class |
ObjectToStringTransformer
A simple transformer that creates an outbound payload by invoking the
inbound payload Object's
toString() method. |
class |
PayloadDeserializingTransformer
Transformer that deserializes the inbound byte array payload to an object by delegating to a
Converter<byte[], Object>.
|
class |
PayloadSerializingTransformer
Transformer that serializes the inbound payload into a byte array by delegating to a
Converter<Object, byte[]>.
|
class |
PayloadTypeConvertingTransformer<T,U>
Transformer that converts the inbound payload to an object by delegating to a
Converter<Object, Object>.
|
class |
SyslogToMapTransformer
Transforms a packet in Syslog (RFC3164) format to a Map.
|
Modifier and Type | Class and Description |
---|---|
class |
DirectMessageReceivingMessageSource
This class handles support for receiving DMs (direct messages) using Twitter.
|
class |
MentionsReceivingMessageSource
Receives Message Tweets
|
class |
SearchReceivingMessageSource |
class |
TimelineReceivingMessageSource
This
MessageSource lets Spring Integration consume
given account's timeline as messages. |
Modifier and Type | Class and Description |
---|---|
class |
DirectMessageSendingMessageHandler
Simple adapter to support sending outbound direct messages ("DM"s) using Twitter.
|
class |
StatusUpdatingMessageHandler
MessageHandler for sending regular status updates as well as 'replies' or 'mentions'.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractWebServiceInboundGateway |
class |
AbstractWebServiceOutboundGateway
Base class for outbound Web Service-invoking Messaging Gateways.
|
class |
MarshallingWebServiceInboundGateway |
class |
MarshallingWebServiceOutboundGateway
An outbound Messaging Gateway for invoking Web Services that also supports
marshalling and unmarshalling of the request and response messages.
|
class |
SimpleWebServiceInboundGateway |
class |
SimpleWebServiceOutboundGateway
An outbound Messaging Gateway for invoking a Web Service.
|
Modifier and Type | Class and Description |
---|---|
class |
XPathRouter
Message Router that uses
XPathExpression evaluation to determine channel names. |
Modifier and Type | Class and Description |
---|---|
class |
XPathMessageSplitter
|
Modifier and Type | Class and Description |
---|---|
class |
MarshallingTransformer
An implementation of
AbstractTransformer that delegates to an OXM Marshaller . |
class |
SourceCreatingTransformer
Transforms the payload to a
Source using a SourceFactory . |
class |
UnmarshallingTransformer
An implementation of
Transformer that delegates to an OXM
Unmarshaller . |
class |
XPathTransformer
Transformer implementation that evaluates an XPath expression against the inbound
Message payload and returns a Message whose payload is the result of that evaluation.
|
class |
XsltPayloadTransformer
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractXmppConnectionAwareEndpoint |
class |
AbstractXmppConnectionAwareMessageHandler |
Modifier and Type | Class and Description |
---|---|
class |
ChatMessageListeningEndpoint
This component logs in as a user and forwards any messages to that
user on to downstream components.
|
class |
PresenceListeningEndpoint
An inbound endpoint that is able to login and then emit
Message s when a
particular Presence event occurs within the logged-in user's Roster . |
Modifier and Type | Class and Description |
---|---|
class |
ChatMessageSendingMessageHandler
MessageHandler that sends an XMPP Chat Message.
|
class |
PresenceSendingMessageHandler
MessageHandler that publishes updated Presence values for a given XMPP connection.
|
Copyright © 2018. All rights reserved.