Package | Description |
---|---|
org.springframework.integration |
Base package for Spring Integration Core.
|
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.outbound |
Provides classes supporting outbound endpoints.
|
org.springframework.integration.channel |
Provides classes representing various channel types.
|
org.springframework.integration.channel.interceptor |
Provides classes related to channel interception.
|
org.springframework.integration.core |
Provides core classes.
|
org.springframework.integration.dispatcher |
Provides classes related to dispatching messages.
|
org.springframework.integration.endpoint |
Provides core classes related to Endpoints.
|
org.springframework.integration.event.core |
Provides Event core classes.
|
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 |
Base package for supporting remote files.
|
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.test |
Provides classes used to support common test cases in modules
that are dependent on the file module.
|
org.springframework.integration.file.transformer |
Provides classes supporting the transformation of file contents
to messages.
|
org.springframework.integration.filter |
Provides classes supporting the filter pattern.
|
org.springframework.integration.gateway |
Provides classes supporting messaging gateways.
|
org.springframework.integration.groovy |
Base package for Groovy support.
|
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.history |
Provides classes supporting the capture of message history.
|
org.springframework.integration.http.inbound |
Provides classes supporting inbound endpoints.
|
org.springframework.integration.http.outbound |
Provides classes supporting outbound endpoints.
|
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.jdbc.store |
Provides JDBC-backed Message Store implementations.
|
org.springframework.integration.jdbc.store.channel |
Provides support classes for the JdbcChannelMessageStore.
|
org.springframework.integration.jms |
Base package for JMS Support.
|
org.springframework.integration.jmx |
Base package for JMX support.
|
org.springframework.integration.jpa.core |
Provides core classes of the JPA module.
|
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.mail.transformer |
Provides classes related to transforming mail messages.
|
org.springframework.integration.mapping |
Provides classes related to mapping to/from message headers.
|
org.springframework.integration.message |
Provides concrete
Message implementations. |
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.mongodb.store |
Provides classes related to the MongoDB message store.
|
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.scripting |
Base package for scripting support.
|
org.springframework.integration.scripting.jsr223 |
Provides classes supporting JSR223 Scripting.
|
org.springframework.integration.security.channel |
Provides classes related to secured channels.
|
org.springframework.integration.selector |
Provides classes related to message selection.
|
org.springframework.integration.splitter |
Provides classes supporting the splitter pattern.
|
org.springframework.integration.store |
Provides classes releated to storing messages.
|
org.springframework.integration.stream |
Base package for stream support.
|
org.springframework.integration.support |
Base core support package.
|
org.springframework.integration.support.converter |
Provides classes supporting message conversion.
|
org.springframework.integration.support.json |
Provides classes supporting json.
|
org.springframework.integration.syslog |
Base package for Syslog Support.
|
org.springframework.integration.syslog.inbound |
Provides classes for inbound endpoints.
|
org.springframework.integration.test.matcher |
Provides several
BaseMatcher implementations. |
org.springframework.integration.test.support |
Provides several test support classes including for testing Spring Integration
request-response message scenarios.
|
org.springframework.integration.test.util |
Provides various test utilities, for example
TestUtils provides convenience
helpers to easily retrieve private bean properties. |
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.outbound |
Provides outbound Twitter components.
|
org.springframework.integration.util |
Provides core utility classes.
|
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.selector |
Provides XML-centric
MessageSelector
implementations. |
org.springframework.integration.xml.splitter |
Provides implementations of
AbstractMessageSplitter . |
org.springframework.integration.xml.transformer |
Provides Transformer and Enricher implementations.
|
org.springframework.integration.xmpp.outbound |
Provides XMPP outbound Messagehandler implementations.These components extend
AbstractXmppConnectionAwareMessageHandler |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessagingException.getFailedMessage() |
Modifier and Type | Method and Description |
---|---|
boolean |
MessageChannel.send(Message<?> message)
Send a
Message to this channel. |
boolean |
MessageChannel.send(Message<?> message,
long timeout)
Send a message, blocking until either the message is accepted or the
specified timeout period elapses.
|
void |
MessagingException.setFailedMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<Object> |
CorrelatingMessageBarrier.receive() |
Modifier and Type | Method and Description |
---|---|
int |
MessageSequenceComparator.compare(Message<?> message1,
Message<?> message2) |
int |
MessageSequenceComparator.compare(Message<?> message1,
Message<?> message2) |
int |
SequenceNumberComparator.compare(Message<?> o1,
Message<?> o2)
If both messages have a sequence number then compare that, otherwise if one has a sequence number and the other
doesn't then the numbered message comes first, or finally of neither has a sequence number then they are equal in
rank.
|
int |
SequenceNumberComparator.compare(Message<?> o1,
Message<?> o2)
If both messages have a sequence number then compare that, otherwise if one has a sequence number and the other
doesn't then the numbered message comes first, or finally of neither has a sequence number then they are equal in
rank.
|
Object |
HeaderAttributeCorrelationStrategy.getCorrelationKey(Message<?> message) |
Object |
ExpressionEvaluatingCorrelationStrategy.getCorrelationKey(Message<?> message) |
Object |
CorrelationStrategy.getCorrelationKey(Message<?> message)
Find the correlation key for the given message.
|
Object |
MethodInvokingCorrelationStrategy.getCorrelationKey(Message<?> message) |
protected void |
AbstractCorrelatingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
CorrelatingMessageBarrier.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
AbstractCorrelatingMessageHandler.afterRelease(MessageGroup group,
Collection<Message<?>> completedMessages)
Allows you to provide additional logic that needs to be performed after the MessageGroup was released.
|
protected void |
AggregatingMessageHandler.afterRelease(MessageGroup messageGroup,
Collection<Message<?>> completedMessages) |
protected void |
ResequencingMessageHandler.afterRelease(MessageGroup messageGroup,
Collection<Message<?>> completedMessages) |
protected int |
AbstractCorrelatingMessageHandler.findLastReleasedSequenceNumber(Object groupId,
Collection<Message<?>> partialSequence) |
Object |
ExpressionEvaluatingMessageListProcessor.process(Collection<? extends Message<?>> messages)
Processes the Message by evaluating the expression with that Message as the root object.
|
Object |
MessageListProcessor.process(Collection<? extends Message<?>> messages) |
T |
MethodInvokingMessageListProcessor.process(Collection<? extends Message<?>> messages,
Map<String,Object> aggregateHeaders) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
PollableAmqpChannel.receive() |
Message<?> |
PollableAmqpChannel.receive(long timeout) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
AbstractAmqpChannel.doSend(Message<?> message,
long timeout) |
Modifier and Type | Method and Description |
---|---|
protected Object |
AmqpOutboundEndpoint.handleRequestMessage(Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
protected Message<?> |
QueueChannel.doReceive(long timeout) |
protected abstract Message<?> |
AbstractPollableChannel.doReceive(long timeout)
Subclasses must implement this method.
|
protected Message<?> |
PriorityChannel.doReceive(long timeout) |
Message<?> |
AbstractMessageChannel.ChannelInterceptorList.postReceive(Message<?> message,
MessageChannel channel) |
Message<?> |
ChannelInterceptor.postReceive(Message<?> message,
MessageChannel channel)
Invoked immediately after a Message has been retrieved but before
it is returned to the caller.
|
Message<?> |
AbstractMessageChannel.ChannelInterceptorList.preSend(Message<?> message,
MessageChannel channel) |
Message<?> |
ChannelInterceptor.preSend(Message<?> message,
MessageChannel channel)
Invoked before the Message is actually sent to the channel.
|
Message<?> |
AbstractPollableChannel.receive()
Receive the first available message from this channel.
|
Message<?> |
NullChannel.receive() |
Message<?> |
AbstractPollableChannel.receive(long timeout)
Receive the first available message from this channel.
|
Message<?> |
NullChannel.receive(long timeout) |
Modifier and Type | Method and Description |
---|---|
List<Message<?>> |
QueueChannel.clear()
Remove all
Messages from this channel. |
List<Message<?>> |
QueueChannelOperations.clear()
Remove all
Messages from this channel. |
List<Message<?>> |
ChannelPurger.purge() |
List<Message<?>> |
QueueChannel.purge(MessageSelector selector)
Remove any
Messages that are not accepted by the provided selector. |
List<Message<?>> |
QueueChannelOperations.purge(MessageSelector selector)
Remove any
Messages that are not accepted by the provided selector. |
Modifier and Type | Method and Description |
---|---|
protected boolean |
QueueChannel.doSend(Message<?> message,
long timeout) |
protected boolean |
AbstractSubscribableChannel.doSend(Message<?> message,
long timeout) |
protected abstract boolean |
AbstractMessageChannel.doSend(Message<?> message,
long timeout)
Subclasses must implement this method.
|
protected boolean |
PriorityChannel.doSend(Message<?> message,
long timeout) |
Message<?> |
AbstractMessageChannel.ChannelInterceptorList.postReceive(Message<?> message,
MessageChannel channel) |
Message<?> |
ChannelInterceptor.postReceive(Message<?> message,
MessageChannel channel)
Invoked immediately after a Message has been retrieved but before
it is returned to the caller.
|
void |
AbstractMessageChannel.ChannelInterceptorList.postSend(Message<?> message,
MessageChannel channel,
boolean sent) |
void |
ChannelInterceptor.postSend(Message<?> message,
MessageChannel channel,
boolean sent)
Invoked immediately after the send invocation.
|
Message<?> |
AbstractMessageChannel.ChannelInterceptorList.preSend(Message<?> message,
MessageChannel channel) |
Message<?> |
ChannelInterceptor.preSend(Message<?> message,
MessageChannel channel)
Invoked before the Message is actually sent to the channel.
|
boolean |
AbstractMessageChannel.send(Message<?> message)
Send a message on this channel.
|
boolean |
NullChannel.send(Message<?> message) |
boolean |
AbstractMessageChannel.send(Message<?> message,
long timeout)
Send a message on this channel.
|
boolean |
NullChannel.send(Message<?> message,
long timeout) |
Constructor and Description |
---|
PriorityChannel(Comparator<Message<?>> comparator)
Create a channel with an unbounded queue.
|
PriorityChannel(int capacity,
Comparator<Message<?>> comparator)
Create a channel with the specified queue capacity.
|
QueueChannel(BlockingQueue<Message<?>> queue)
Create a channel with the specified queue.
|
Modifier and Type | Method and Description |
---|---|
Message<?> |
ChannelInterceptorAdapter.postReceive(Message<?> message,
MessageChannel channel) |
Message<?> |
ChannelInterceptorAdapter.preSend(Message<?> message,
MessageChannel channel) |
Message<?> |
WireTap.preSend(Message<?> message,
MessageChannel channel)
Intercept the Message and, if accepted by the
MessageSelector ,
send it to the secondary target. |
Message<?> |
MessageSelectingInterceptor.preSend(Message<?> message,
MessageChannel channel) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
ChannelInterceptorAdapter.postReceive(Message<?> message,
MessageChannel channel) |
void |
ChannelInterceptorAdapter.postSend(Message<?> message,
MessageChannel channel,
boolean sent) |
Message<?> |
ChannelInterceptorAdapter.preSend(Message<?> message,
MessageChannel channel) |
Message<?> |
WireTap.preSend(Message<?> message,
MessageChannel channel)
Intercept the Message and, if accepted by the
MessageSelector ,
send it to the secondary target. |
Message<?> |
MessageSelectingInterceptor.preSend(Message<?> message,
MessageChannel channel) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessagePostProcessor.postProcessMessage(Message<?> message)
Apply a MessagePostProcessor to the message.
|
Message<?> |
PollableChannel.receive()
Receive a message from this channel, blocking indefinitely if necessary.
|
Message<T> |
MessageSource.receive()
Retrieve the next available message from this source.
|
<P> Message<P> |
MessagingOperations.receive()
Receive a message synchronously from the default channel, but only
wait up to a specified time for delivery.
|
<P> Message<P> |
MessagingTemplate.receive() |
Message<?> |
PollableChannel.receive(long timeout)
Receive a message from this channel, blocking until either a message is
available or the specified timeout period elapses.
|
<P> Message<P> |
MessagingOperations.receive(PollableChannel channel)
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
|
<P> Message<P> |
MessagingTemplate.receive(PollableChannel channel) |
<P> Message<P> |
MessagingOperations.receive(String channelName)
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
|
<P> Message<P> |
MessagingTemplate.receive(String channelName) |
Message<?> |
MessagingOperations.sendAndReceive(Message<?> requestMessage)
Send a message to the default channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(Message<?> requestMessage) |
Message<?> |
MessagingOperations.sendAndReceive(MessageChannel channel,
Message<?> requestMessage)
Send a message to the specified channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Message<?> |
MessagingOperations.sendAndReceive(String channelName,
Message<?> requestMessage)
Send a message to the specified channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(String channelName,
Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
Future<Message<?>> |
AsyncMessagingOperations.asyncReceive() |
Future<Message<?>> |
AsyncMessagingTemplate.asyncReceive() |
Future<Message<?>> |
AsyncMessagingOperations.asyncReceive(PollableChannel channel) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncReceive(PollableChannel channel) |
Future<Message<?>> |
AsyncMessagingOperations.asyncReceive(String channelName) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncReceive(String channelName) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(String channelName,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(String channelName,
Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
boolean |
MessageSelector.accept(Message<?> message) |
Future<?> |
AsyncMessagingOperations.asyncSend(Message<?> message) |
Future<?> |
AsyncMessagingTemplate.asyncSend(Message<?> message) |
Future<?> |
AsyncMessagingOperations.asyncSend(MessageChannel channel,
Message<?> message) |
Future<?> |
AsyncMessagingTemplate.asyncSend(MessageChannel channel,
Message<?> message) |
Future<?> |
AsyncMessagingOperations.asyncSend(String channelName,
Message<?> message) |
Future<?> |
AsyncMessagingTemplate.asyncSend(String channelName,
Message<?> message) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingOperations.asyncSendAndReceive(String channelName,
Message<?> requestMessage) |
Future<Message<?>> |
AsyncMessagingTemplate.asyncSendAndReceive(String channelName,
Message<?> requestMessage) |
void |
MessageHandler.handleMessage(Message<?> message)
Handles the message if possible.
|
Message<?> |
MessagePostProcessor.postProcessMessage(Message<?> message)
Apply a MessagePostProcessor to the message.
|
<P> void |
MessagingOperations.send(Message<P> message)
Send a message to the default channel.
|
<P> void |
MessagingTemplate.send(Message<P> message) |
<P> void |
MessagingOperations.send(MessageChannel channel,
Message<P> message)
Send a message to the specified channel.
|
<P> void |
MessagingTemplate.send(MessageChannel channel,
Message<P> message) |
<P> void |
MessagingOperations.send(String channelName,
Message<P> message)
Send a message to the specified channel.
|
<P> void |
MessagingTemplate.send(String channelName,
Message<P> message) |
Message<?> |
MessagingOperations.sendAndReceive(Message<?> requestMessage)
Send a message to the default channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(Message<?> requestMessage) |
Message<?> |
MessagingOperations.sendAndReceive(MessageChannel channel,
Message<?> requestMessage)
Send a message to the specified channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(MessageChannel channel,
Message<?> requestMessage) |
Message<?> |
MessagingOperations.sendAndReceive(String channelName,
Message<?> requestMessage)
Send a message to the specified channel and receive a reply.
|
Message<?> |
MessagingTemplate.sendAndReceive(String channelName,
Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
boolean |
UnicastingDispatcher.dispatch(Message<?> message) |
boolean |
MessageDispatcher.dispatch(Message<?> message) |
boolean |
BroadcastingDispatcher.dispatch(Message<?> message) |
Iterator<MessageHandler> |
RoundRobinLoadBalancingStrategy.getHandlerIterator(Message<?> message,
Collection<MessageHandler> handlers)
Returns an iterator that starts at a new point in the collection every time the
first part of the list that is skipped will be used at the end of the
iteration, so it guarantees all handlers are returned once on subsequent
next() invocations. |
Iterator<MessageHandler> |
LoadBalancingStrategy.getHandlerIterator(Message<?> message,
Collection<MessageHandler> handlers) |
Constructor and Description |
---|
AggregateMessageDeliveryException(Message<?> undeliveredMessage,
String description,
List<? extends Exception> aggregatedExceptions) |
Modifier and Type | Method and Description |
---|---|
Message<T> |
AbstractMessageSource.receive() |
protected Message<?> |
PollingConsumer.receiveMessage() |
protected Message<?> |
SourcePollingChannelAdapter.receiveMessage() |
protected abstract Message<?> |
AbstractPollingEndpoint.receiveMessage()
Obtain the next message (if one is available).
|
Modifier and Type | Method and Description |
---|---|
protected void |
PollingConsumer.handleMessage(Message<?> message) |
protected void |
SourcePollingChannelAdapter.handleMessage(Message<?> message) |
protected abstract void |
AbstractPollingEndpoint.handleMessage(Message<?> message)
Handle a message.
|
protected void |
MessageProducerSupport.sendMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessagingEvent.getMessage() |
Constructor and Description |
---|
MessagingEvent(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected void |
ApplicationEventPublishingMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<com.rometools.rome.feed.synd.SyndEntry> |
FeedEntryMessageSource.receive() |
Modifier and Type | Method and Description |
---|---|
Message<File> |
FileReadingMessageSource.receive() |
Modifier and Type | Method and Description |
---|---|
String |
DefaultFileNameGenerator.generateFileName(Message<?> message) |
String |
FileNameGenerator.generateFileName(Message<?> message) |
protected Object |
FileWritingMessageHandler.handleRequestMessage(Message<?> requestMessage) |
void |
FileReadingMessageSource.onFailure(Message<File> failedMessage)
Adds the failed message back to the 'toBeReceived' queue if there is room.
|
void |
FileReadingMessageSource.onSend(Message<File> sentMessage)
The message is just logged.
|
Modifier and Type | Method and Description |
---|---|
boolean |
RemoteFileTemplate.get(Message<?> message,
InputStreamCallback callback) |
boolean |
RemoteFileOperations.get(Message<?> message,
InputStreamCallback callback)
Retrieve a remote file as an InputStream, based on information in a message.
|
String |
RemoteFileTemplate.send(Message<?> message) |
String |
RemoteFileOperations.send(Message<?> message)
Send a file to a remote server, based on information in a message.
|
String |
RemoteFileTemplate.send(Message<?> message,
String subDirectory) |
String |
RemoteFileOperations.send(Message<?> message,
String subDirectory)
Send a file to a remote server, based on information in a message.
|
Modifier and Type | Method and Description |
---|---|
protected File |
AbstractRemoteFileOutboundGateway.get(Message<?> message,
Session<F> session,
String remoteDir,
String remoteFilePath,
String remoteFilename,
boolean lsFirst)
Copy a remote file to the configured local directory.
|
protected Object |
AbstractRemoteFileOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
protected List<File> |
AbstractRemoteFileOutboundGateway.mGet(Message<?> message,
Session<F> session,
String remoteDirectory,
String remoteFilename) |
Modifier and Type | Method and Description |
---|---|
protected void |
FileTransferringMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<File> |
AbstractInboundFileSynchronizingMessageSource.receive()
Polls from the file source.
|
Modifier and Type | Method and Description |
---|---|
protected Message<List<File>> |
BigMGetTests.mgetManyFiles() |
Modifier and Type | Method and Description |
---|---|
Message<?> |
AbstractFilePayloadTransformer.transform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
AbstractFilePayloadTransformer.transform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected Object |
MessageFilter.doHandleRequestMessage(Message<?> message) |
Object |
MessageFilter.postProcess(Message<?> message,
Object result) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
RequestReplyExchanger.exchange(Message<?> request) |
protected Message<?> |
MessagingGatewaySupport.sendAndReceiveMessage(Object object) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
RequestReplyExchanger.exchange(Message<?> request) |
Modifier and Type | Method and Description |
---|---|
protected String |
GroovyCommandMessageProcessor.generateScriptName(Message<?> message) |
protected org.springframework.scripting.ScriptSource |
GroovyScriptExecutingMessageProcessor.getScriptSource(Message<?> message) |
protected org.springframework.scripting.ScriptSource |
GroovyCommandMessageProcessor.getScriptSource(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
DelayHandler.DelayedMessageWrapper.getOriginal() |
Modifier and Type | Method and Description |
---|---|
protected abstract Object |
AbstractReplyProducingPostProcessingMessageHandler.doHandleRequestMessage(Message<?> requestMessage) |
protected Object |
AbstractReplyProducingPostProcessingMessageHandler.doInvokeAdvisedRequestHandler(Message<?> message) |
protected Object |
AbstractReplyProducingMessageHandler.doInvokeAdvisedRequestHandler(Message<?> message) |
void |
AbstractMessageHandler.handleMessage(Message<?> message) |
protected abstract void |
AbstractMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
MessageHandlerChain.handleMessageInternal(Message<?> message) |
protected void |
LoggingHandler.handleMessageInternal(Message<?> message) |
protected void |
MethodInvokingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
ExpressionEvaluatingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
AbstractReplyProducingMessageHandler.handleMessageInternal(Message<?> message) |
protected Object |
AbstractReplyProducingPostProcessingMessageHandler.handleRequestMessage(Message<?> requestMessage) |
protected Object |
BridgeHandler.handleRequestMessage(Message<?> requestMessage) |
protected Object |
ServiceActivatingHandler.handleRequestMessage(Message<?> message) |
protected Object |
DelayHandler.handleRequestMessage(Message<?> requestMessage)
Checks if 'requestMessage' wasn't delayed before
(
DelayHandler.releaseMessageAfterDelay(org.springframework.integration.Message<?>, long) and DelayHandler.DelayedMessageWrapper ). |
protected abstract Object |
AbstractReplyProducingMessageHandler.handleRequestMessage(Message<?> requestMessage)
Subclasses must implement this method to handle the request Message.
|
Object |
AbstractReplyProducingMessageHandler.RequestHandler.handleRequestMessage(Message<?> requestMessage) |
Object |
PostProcessingMessageHandler.postProcess(Message<?> message,
Object result)
Take some further action on the result and/or message.
|
T |
ExpressionEvaluatingMessageProcessor.processMessage(Message<?> message)
Processes the Message by evaluating the expression with that Message as the
root object.
|
T |
MethodInvokingMessageProcessor.processMessage(Message<?> message) |
T |
MessageProcessor.processMessage(Message<?> message)
Process the Message and return a value (or null).
|
Object |
ExpressionCommandMessageProcessor.processMessage(Message<?> message)
Evaluates the Message payload expression as a command.
|
abstract T |
AbstractMessageProcessor.processMessage(Message<?> message) |
Constructor and Description |
---|
ReplyRequiredException(Message<?> failedMessage,
String description) |
Modifier and Type | Method and Description |
---|---|
org.springframework.retry.RetryState |
RetryStateGenerator.determineRetryState(Message<?> message) |
org.springframework.retry.RetryState |
SpelExpressionRetryStateGenerator.determineRetryState(Message<?> message) |
protected Object |
RequestHandlerRetryAdvice.doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback callback,
Object target,
Message<?> message) |
protected Object |
RequestHandlerCircuitBreakerAdvice.doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback callback,
Object target,
Message<?> message) |
protected Object |
ExpressionEvaluatingRequestHandlerAdvice.doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback callback,
Object target,
Message<?> message) |
protected abstract Object |
AbstractRequestHandlerAdvice.doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback callback,
Object target,
Message<?> message)
Subclasses implement this method to apply behavior to the
MessageHandler . |
Constructor and Description |
---|
MessageHandlingExpressionEvaluatingAdviceException(Message<?> message,
String description,
Throwable cause,
Object evaluationResult) |
RetryExceptionNotAvailableException(Message<?> message,
String description) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
HistoryWritingMessagePostProcessor.postProcessMessage(Message<?> message) |
static <T> Message<T> |
MessageHistory.write(Message<T> message,
NamedComponent component) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
HistoryWritingMessagePostProcessor.postProcessMessage(Message<?> message) |
static MessageHistory |
MessageHistory.read(Message<?> message) |
static <T> Message<T> |
MessageHistory.write(Message<T> message,
NamedComponent component) |
Modifier and Type | Method and Description |
---|---|
protected Message<?> |
HttpRequestHandlingEndpointSupport.doHandleRequest(javax.servlet.http.HttpServletRequest servletRequest,
javax.servlet.http.HttpServletResponse servletResponse)
Handles the HTTP request by generating a Message and sending it to the request channel.
|
Modifier and Type | Method and Description |
---|---|
protected Object |
HttpRequestHandlingEndpointSupport.setupResponseAndConvertReply(org.springframework.http.server.ServletServerHttpResponse response,
Message<?> replyMessage)
Converts the reply message to the appropriate HTTP reply object and
sets up the
ServletServerHttpResponse . |
Modifier and Type | Method and Description |
---|---|
protected Object |
HttpRequestExecutingMessageHandler.handleRequestMessage(Message<?> requestMessage) |
protected org.springframework.http.HttpHeaders |
HttpRequestExecutingMessageHandler.mapHeaders(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected void |
TcpSendingMessageHandler.doWrite(Message<?> message)
Method that actually does the write.
|
void |
TcpSendingMessageHandler.handleMessageInternal(Message<?> message)
Writes the message payload to the underlying socket, using the specified
message format.
|
protected Object |
TcpOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
protected TcpConnection |
TcpSendingMessageHandler.obtainConnection(Message<?> message) |
boolean |
TcpOutboundGateway.onMessage(Message<?> message) |
boolean |
TcpInboundGateway.onMessage(Message<?> message) |
boolean |
TcpReceivingChannelAdapter.onMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected Message<TcpConnectionEvent> |
TcpConnectionEventListeningMessageProducer.messageFromEvent(TcpConnectionEvent event) |
Message<Object> |
MessageConvertingTcpMessageMapper.toMessage(TcpConnection connection) |
Message<Object> |
TcpMessageMapper.toMessage(TcpConnection connection) |
Modifier and Type | Method and Description |
---|---|
void |
TcpConnectionSupport.afterSend(Message<?> message) |
Object |
MessageConvertingTcpMessageMapper.fromMessage(Message<?> message) |
Object |
TcpMessageMapper.fromMessage(Message<?> message) |
boolean |
TcpConnectionInterceptorSupport.onMessage(Message<?> message) |
boolean |
TcpListener.onMessage(Message<?> message)
Called by a TCPConnection when a new message arrives.
|
void |
TcpConnection.send(Message<?> message)
Converts and sends the message.
|
void |
TcpNioConnection.send(Message<?> message) |
void |
TcpConnectionInterceptorSupport.send(Message<?> message) |
void |
TcpNetConnection.send(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<byte[]> |
DatagramPacketMessageMapper.toMessage(DatagramPacket packet) |
Modifier and Type | Method and Description |
---|---|
DatagramPacket |
DatagramPacketMessageMapper.fromMessage(Message<?> message)
Raw byte[] from message, possibly with a length field up front.
|
void |
UnicastSendingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
UnicastReceivingChannelAdapter.sendAck(Message<byte[]> message) |
Modifier and Type | Method and Description |
---|---|
<T> Message<T> |
JdbcMessageStore.addMessage(Message<T> message) |
protected Message<?> |
JdbcMessageStore.doPollForMessage(String groupIdKey)
This method executes a call to the DB to get the oldest Message in the MessageGroup
Override this method if need to.
|
Message<?> |
JdbcMessageStore.getMessage(UUID id) |
Message<?> |
JdbcMessageStore.pollMessageFromGroup(Object groupId) |
Message<Object> |
JdbcPollingChannelAdapter.receive()
Executes the query.
|
Message<Object> |
StoredProcPollingChannelAdapter.receive()
Executes the query.
|
Message<?> |
JdbcMessageStore.removeMessage(UUID id) |
Modifier and Type | Method and Description |
---|---|
<T> Message<T> |
JdbcMessageStore.addMessage(Message<T> message) |
MessageGroup |
JdbcMessageStore.addMessageToGroup(Object groupId,
Message<?> message) |
Map<String,Object> |
StoredProcExecutor.executeStoredProcedure(Message<?> message)
Execute a Stored Procedure or Function - Use with
Message is
available to extract ProcedureParameter values from it. |
protected void |
JdbcMessageHandler.handleMessageInternal(Message<?> message)
Executes the update, passing the message into the
SqlParameterSourceFactory . |
protected void |
StoredProcMessageHandler.handleMessageInternal(Message<?> message)
Executes the Stored procedure, delegates to executeStoredProcedure(...).
|
protected Object |
StoredProcOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
protected Object |
JdbcOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
MessageGroup |
JdbcMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcMessageStore.setDeserializer(org.springframework.core.serializer.Deserializer<? extends Message<?>> deserializer)
A converter for deserializing byte arrays to messages.
|
void |
JdbcMessageStore.setSerializer(org.springframework.core.serializer.Serializer<? super Message<?>> serializer)
A converter for serializing messages to byte arrays for storage.
|
Modifier and Type | Method and Description |
---|---|
protected Message<?> |
JdbcChannelMessageStore.doPollForMessage(String groupIdKey)
This method executes a call to the DB to get the oldest Message in the
MessageGroup which in the context of the
JdbcChannelMessageStore
means the channel identifier. |
Message<?> |
JdbcChannelMessageStore.pollMessageFromGroup(Object groupId)
Polls the database for a new message that is persisted for the given
group id which represents the channel identifier.
|
Modifier and Type | Method and Description |
---|---|
MessageGroup |
JdbcChannelMessageStore.addMessageToGroup(Object groupId,
Message<?> message)
Store a message in the database.
|
MessageGroup |
JdbcChannelMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove)
Remove a single message from the database.
|
Modifier and Type | Method and Description |
---|---|
void |
JdbcChannelMessageStore.setDeserializer(org.springframework.core.serializer.Deserializer<? extends Message<?>> deserializer)
A converter for deserializing byte arrays to messages.
|
void |
JdbcChannelMessageStore.setSerializer(org.springframework.core.serializer.Serializer<? super Message<?>> serializer)
A converter for serializing messages to byte arrays for storage.
|
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessageRowMapper.mapRow(ResultSet rs,
int rowNum) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
PollableJmsChannel.receive() |
Message<Object> |
JmsDestinationPollingSource.receive()
Will receive a JMS
Message converting and returning it as
a Spring Integration Message . |
Message<?> |
PollableJmsChannel.receive(long timeout) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
AbstractJmsChannel.doSend(Message<?> message,
long timeout) |
protected void |
JmsSendingMessageHandler.handleMessageInternal(Message<?> message) |
protected Object |
JmsOutboundGateway.handleRequestMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected void |
NotificationPublishingMessageHandler.handleMessageInternal(Message<?> message) |
protected Object |
OperationInvokingMessageHandler.handleRequestMessage(Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
Object |
JpaExecutor.executeOutboundJpaOperation(Message<?> message)
Executes the actual Jpa Operation.
|
Object |
JpaExecutor.poll(Message<?> requestMessage)
Execute a (typically retrieving) JPA operation.
|
Modifier and Type | Method and Description |
---|---|
Message<Object> |
JpaPollingChannelAdapter.receive()
Uses
JpaExecutor.poll() to executes the JPA operation. |
Modifier and Type | Method and Description |
---|---|
protected Object |
JpaOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
protected Object |
ObjectToJsonTransformer.doTransform(Message<?> message) |
protected Object |
JsonToObjectTransformer.doTransform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<javax.mail.Message> |
MailReceivingMessageSource.receive() |
Modifier and Type | Method and Description |
---|---|
protected void |
MailSendingMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
AbstractMailMessageTransformer.transform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
AbstractMailMessageTransformer.transform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
InboundMessageMapper.toMessage(T object) |
Modifier and Type | Method and Description |
---|---|
T |
OutboundMessageMapper.fromMessage(Message<?> message) |
Constructor and Description |
---|
MessageMappingException(Message<?> failedMessage,
String description) |
MessageMappingException(Message<?> failedMessage,
String description,
Throwable cause) |
Modifier and Type | Class and Description |
---|---|
class |
AdviceMessage
A message implementation that is produced by an advice after
successful message handling.
|
class |
ErrorMessage
A message implementation that accepts a
Throwable payload. |
class |
GenericMessage<T>
Base Message class defining common properties such as id, payload, and headers.
|
Modifier and Type | Method and Description |
---|---|
Message<?> |
AdviceMessage.getInputMessage() |
Constructor and Description |
---|
AdviceMessage(Object payload,
Map<String,Object> headers,
Message<?> inputMessage) |
AdviceMessage(Object payload,
Message<?> inputMessage) |
Modifier and Type | Method and Description |
---|---|
Message<Object> |
MongoDbMessageSource.receive()
Will execute a
Query returning its results as the Message payload. |
Modifier and Type | Method and Description |
---|---|
protected void |
MongoDbStoringMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
<T> Message<T> |
MongoDbMessageStore.addMessage(Message<T> message) |
<T> Message<T> |
ConfigurableMongoDbMessageStore.addMessage(Message<T> message) |
Message<?> |
MongoDbMessageStore.getMessage(UUID id) |
Message<?> |
ConfigurableMongoDbMessageStore.getMessage(UUID id) |
Message<?> |
MongoDbMessageStore.pollMessageFromGroup(Object groupId) |
Message<?> |
ConfigurableMongoDbMessageStore.pollMessageFromGroup(Object groupId) |
Message<?> |
MongoDbMessageStore.removeMessage(UUID id) |
Message<?> |
ConfigurableMongoDbMessageStore.removeMessage(UUID id) |
Modifier and Type | Method and Description |
---|---|
<T> Message<T> |
MongoDbMessageStore.addMessage(Message<T> message) |
<T> Message<T> |
ConfigurableMongoDbMessageStore.addMessage(Message<T> message) |
MessageGroup |
MongoDbMessageStore.addMessageToGroup(Object groupId,
Message<?> message) |
MessageGroup |
ConfigurableMongoDbMessageStore.addMessageToGroup(Object groupId,
Message<?> message) |
MessageGroup |
MongoDbMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove) |
MessageGroup |
ConfigurableMongoDbMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
SubscribableRedisChannel.doSend(Message<?> message,
long arg1) |
Modifier and Type | Method and Description |
---|---|
Message<org.springframework.data.redis.support.collections.RedisStore> |
RedisStoreMessageSource.receive()
Returns a Message with the view into a
RedisStore identified
by RedisStoreMessageSource.keyExpression |
Modifier and Type | Method and Description |
---|---|
protected void |
RedisStoreWritingMessageHandler.handleMessageInternal(Message<?> message)
Will extract the payload from the Message and store it in the collection identified by the
key (which may be determined by an expression).
|
protected void |
RedisQueueOutboundChannelAdapter.handleMessageInternal(Message<?> message) |
protected void |
RedisPublishingMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
RmiInboundGateway.exchange(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
RmiInboundGateway.exchange(Message<?> message) |
Object |
RmiOutboundGateway.handleRequestMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
boolean |
RecipientListRouter.Recipient.accept(Message<?> message) |
protected abstract Collection<MessageChannel> |
AbstractMessageRouter.determineTargetChannels(Message<?> message)
Subclasses must implement this method to return a Collection of zero or more
MessageChannels to which the given Message should be routed.
|
protected Collection<MessageChannel> |
RecipientListRouter.determineTargetChannels(Message<?> message) |
protected Collection<MessageChannel> |
AbstractMappingMessageRouter.determineTargetChannels(Message<?> message) |
protected List<Object> |
HeaderValueRouter.getChannelKeys(Message<?> message) |
protected List<Object> |
PayloadTypeRouter.getChannelKeys(Message<?> message)
Selects the most appropriate channel name matching channel identifiers which are the
fully qualified class names encountered while traversing the payload type hierarchy.
|
protected List<Object> |
ErrorMessageExceptionTypeRouter.getChannelKeys(Message<?> message) |
protected abstract List<Object> |
AbstractMappingMessageRouter.getChannelKeys(Message<?> message)
Subclasses must implement this method to return the channel keys.
|
protected void |
AbstractMessageRouter.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Map<String,Object> |
DefaultScriptVariableGenerator.generateScriptVariables(Message<?> message) |
Map<String,Object> |
ScriptVariableGenerator.generateScriptVariables(Message<?> message) |
protected abstract org.springframework.scripting.ScriptSource |
AbstractScriptExecutingMessageProcessor.getScriptSource(Message<?> message)
Subclasses must implement this method to create a script source,
optionally using the message to locate or create the script.
|
T |
AbstractScriptExecutingMessageProcessor.processMessage(Message<?> message)
Executes the script and returns the result.
|
Modifier and Type | Method and Description |
---|---|
protected org.springframework.scripting.ScriptSource |
ScriptExecutingMessageProcessor.getScriptSource(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
ChannelInvocation.getMessage() |
Modifier and Type | Method and Description |
---|---|
boolean |
MessageSelectorChain.accept(Message<?> message)
Pass the message through the selector chain.
|
boolean |
PayloadTypeSelector.accept(Message<?> message) |
boolean |
UnexpiredMessageSelector.accept(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected Object |
AbstractMessageSplitter.handleRequestMessage(Message<?> message) |
protected Object |
DefaultMessageSplitter.splitMessage(Message<?> message) |
protected abstract Object |
AbstractMessageSplitter.splitMessage(Message<?> message)
Subclasses must override this method to split the received Message.
|
Modifier and Type | Field and Description |
---|---|
BlockingQueue<Message<?>> |
SimpleMessageGroup.messages |
Modifier and Type | Method and Description |
---|---|
<T> Message<T> |
MessageStore.addMessage(Message<T> message)
Put the provided Message into the MessageStore.
|
<T> Message<T> |
SimpleMessageStore.addMessage(Message<T> message) |
<T> Message<T> |
AbstractKeyValueMessageStore.addMessage(Message<T> message) |
Message<?> |
MessageStore.getMessage(UUID id)
Return the Message with the given id, or null if no Message with that id exists in the MessageStore.
|
Message<?> |
SimpleMessageStore.getMessage(UUID key) |
Message<?> |
AbstractKeyValueMessageStore.getMessage(UUID id) |
Message<?> |
MessageGroup.getOne() |
Message<?> |
SimpleMessageGroup.getOne() |
Message<?> |
MessageGroupQueue.peek() |
Message<?> |
MessageGroupQueue.poll() |
Message<?> |
MessageGroupQueue.poll(long timeout,
TimeUnit unit) |
Message<?> |
MessageGroupStore.pollMessageFromGroup(Object groupId)
Polls Message from this
MessageGroup (in FIFO style if supported by the implementation)
while also removing the polled Message |
Message<?> |
SimpleMessageStore.pollMessageFromGroup(Object groupId) |
Message<?> |
AbstractKeyValueMessageStore.pollMessageFromGroup(Object groupId) |
Message<?> |
MessageStore.removeMessage(UUID id)
Remove the Message with the given id from the MessageStore, if present, and return it.
|
Message<?> |
SimpleMessageStore.removeMessage(UUID key) |
Message<?> |
AbstractKeyValueMessageStore.removeMessage(UUID id) |
Message<?> |
MessageGroupQueue.take() |
Modifier and Type | Method and Description |
---|---|
Collection<Message<?>> |
MessageGroup.getMessages()
Returns all available Messages from the group at the time of invocation
|
Collection<Message<?>> |
SimpleMessageGroup.getMessages() |
Iterator<Message<?>> |
MessageGroupQueue.iterator() |
Modifier and Type | Method and Description |
---|---|
void |
SimpleMessageGroup.add(Message<?> message) |
<T> Message<T> |
MessageStore.addMessage(Message<T> message)
Put the provided Message into the MessageStore.
|
<T> Message<T> |
SimpleMessageStore.addMessage(Message<T> message) |
<T> Message<T> |
AbstractKeyValueMessageStore.addMessage(Message<T> message) |
MessageGroup |
MessageGroupStore.addMessageToGroup(Object groupId,
Message<?> message)
Store a message with an association to a group id.
|
MessageGroup |
SimpleMessageStore.addMessageToGroup(Object groupId,
Message<?> message) |
MessageGroup |
AbstractKeyValueMessageStore.addMessageToGroup(Object groupId,
Message<?> message)
Add a Message to the group with the provided group ID.
|
boolean |
MessageGroup.canAdd(Message<?> message)
Query if the message can be added.
|
boolean |
SimpleMessageGroup.canAdd(Message<?> message) |
boolean |
MessageGroupQueue.offer(Message<?> message) |
boolean |
MessageGroupQueue.offer(Message<?> message,
long timeout,
TimeUnit unit) |
void |
MessageGroupQueue.put(Message<?> message) |
boolean |
SimpleMessageGroup.remove(Message<?> message) |
MessageGroup |
MessageGroupStore.removeMessageFromGroup(Object key,
Message<?> messageToRemove)
Persist a deletion on a single message from the group.
|
MessageGroup |
SimpleMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove) |
MessageGroup |
AbstractKeyValueMessageStore.removeMessageFromGroup(Object groupId,
Message<?> messageToRemove)
Remove a Message from the group with the provided group ID.
|
Modifier and Type | Method and Description |
---|---|
int |
MessageGroupQueue.drainTo(Collection<? super Message<?>> c) |
int |
MessageGroupQueue.drainTo(Collection<? super Message<?>> collection,
int maxElements) |
Constructor and Description |
---|
MessageStoreException(Message<?> message) |
MessageStoreException(Message<?> message,
String description) |
MessageStoreException(Message<?> message,
String description,
Throwable cause) |
MessageStoreException(Message<?> message,
Throwable cause) |
Constructor and Description |
---|
SimpleMessageGroup(Collection<? extends Message<?>> messages,
Object groupId) |
SimpleMessageGroup(Collection<? extends Message<?>> messages,
Object groupId,
long timestamp,
boolean complete) |
Modifier and Type | Method and Description |
---|---|
Message<String> |
CharacterStreamReadingMessageSource.receive() |
Message<byte[]> |
ByteStreamReadingMessageSource.receive() |
Modifier and Type | Method and Description |
---|---|
protected void |
CharacterStreamWritingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
ByteStreamWritingMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<T> |
MessageBuilder.build() |
Modifier and Type | Method and Description |
---|---|
static <T> MessageBuilder<T> |
MessageBuilder.fromMessage(Message<T> message)
Create a builder for a new
Message instance pre-populated with all of the headers copied from the
provided message. |
Modifier and Type | Method and Description |
---|---|
<P> Message<P> |
MessageConverter.toMessage(Object object) |
<P> Message<P> |
MapMessageConverter.toMessage(Object object) |
<P> Message<P> |
SimpleMessageConverter.toMessage(Object object) |
Modifier and Type | Method and Description |
---|---|
<P> Object |
MessageConverter.fromMessage(Message<P> message) |
<P> Object |
MapMessageConverter.fromMessage(Message<P> message) |
<P> Object |
SimpleMessageConverter.fromMessage(Message<P> message) |
Constructor and Description |
---|
MessageConversionException(Message<?> failedMessage,
String description,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
JsonInboundMessageMapper.JsonMessageParser.doInParser(JsonInboundMessageMapper messageMapper,
String jsonMessage) |
protected Message<?> |
Jackson2JsonMessageParser.parseWithHeaders(com.fasterxml.jackson.core.JsonParser parser,
String jsonMessage) |
protected Message<?> |
JacksonJsonMessageParser.parseWithHeaders(org.codehaus.jackson.JsonParser parser,
String jsonMessage) |
Message<?> |
JsonInboundMessageMapper.toMessage(String jsonMessage) |
Modifier and Type | Method and Description |
---|---|
String |
JsonOutboundMessageMapper.fromMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessageConverter.fromSyslog(Message<?> syslog) |
Message<?> |
DefaultMessageConverter.fromSyslog(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessageConverter.fromSyslog(Message<?> syslog) |
Message<?> |
DefaultMessageConverter.fromSyslog(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected void |
SyslogReceivingChannelAdapterSupport.convertAndSend(Message<?> message) |
boolean |
TcpSyslogReceivingChannelAdapter.onMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
static Message<?> |
MockitoMessageMatchers.messageWithHeaderEntries(Map<String,?> entries) |
static <T> Message<?> |
MockitoMessageMatchers.messageWithHeaderEntry(String key,
org.hamcrest.Matcher<T> valueMatcher) |
static Message<?> |
MockitoMessageMatchers.messageWithHeaderEntry(String key,
Object value) |
static Message<?> |
MockitoMessageMatchers.messageWithHeaderKey(String key) |
static <T> Message<T> |
MockitoMessageMatchers.messageWithPayload(org.hamcrest.Matcher<T> payloadMatcher) |
static <T> Message<T> |
MockitoMessageMatchers.messageWithPayload(T payload) |
Modifier and Type | Method and Description |
---|---|
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasAllHeaders(Map<String,?> entries) |
static <T> org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasCorrelationId(T value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasExpirationDate(Date value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasExpirationDate(org.hamcrest.Matcher<Long> matcher) |
static <T> org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasHeader(String key,
org.hamcrest.Matcher<?> valueMatcher) |
static <T> org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasHeader(String key,
T value) |
static <T> org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasHeaderKey(String key) |
static <T> org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasMessageId(T value) |
static <T> org.hamcrest.Matcher<Message> |
PayloadMatcher.hasPayload(org.hamcrest.Matcher<? super T> payloadMatcher) |
static <T> org.hamcrest.Matcher<Message> |
PayloadMatcher.hasPayload(T payload) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasSequenceNumber(Integer value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasSequenceNumber(org.hamcrest.Matcher<Integer> matcher) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasSequenceSize(Integer value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasSequenceSize(org.hamcrest.Matcher<Integer> value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasTimestamp(Date value) |
static org.hamcrest.Matcher<Message<?>> |
HeaderMatcher.hasTimestamp(org.hamcrest.Matcher<Long> matcher) |
static org.hamcrest.Matcher<Message<?>> |
PayloadAndHeaderMatcher.sameExceptIgnorableHeaders(Message<?> expected,
String... ignoreKeys) |
Modifier and Type | Method and Description |
---|---|
boolean |
PayloadMatcher.matchesSafely(Message message)
Subclasses should implement this.
|
boolean |
HeaderMatcher.matchesSafely(Message<?> item)
Subclasses should implement this.
|
static org.hamcrest.Matcher<Message<?>> |
PayloadAndHeaderMatcher.sameExceptIgnorableHeaders(Message<?> expected,
String... ignoreKeys) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
AbstractResponseValidator.getLastMessage() |
protected Message<? extends Object> |
RequestResponseScenario.getMessage() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractResponseValidator.handleMessage(Message<?> message)
handle the message
|
RequestResponseScenario |
RequestResponseScenario.setMessage(Message<?> message)
Set the request message (as an alternative to setPayload())
|
protected abstract void |
MessageValidator.validateMessage(Message<?> message)
Implement this method to validate the message
|
protected void |
MessageValidator.validateResponse(Message<?> response) |
Modifier and Type | Method and Description |
---|---|
static MessageHandler |
TestUtils.handlerExpecting(org.hamcrest.Matcher<Message> messageMatcher) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
IntegrationResourceHolder.getMessage() |
Modifier and Type | Method and Description |
---|---|
void |
IntegrationResourceHolder.setMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessageTransformingChannelInterceptor.postReceive(Message<?> message,
MessageChannel channel)
Deprecated.
|
Message<?> |
MessageTransformingChannelInterceptor.preSend(Message<?> message,
MessageChannel channel)
Deprecated.
|
Message<?> |
HeaderEnricher.transform(Message<?> message) |
Message<?> |
AbstractTransformer.transform(Message<?> message) |
Message<?> |
HeaderFilter.transform(Message<?> message) |
Message<?> |
Transformer.transform(Message<?> message) |
Message<?> |
AbstractMessageProcessingTransformer.transform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected abstract Object |
AbstractTransformer.doTransform(Message<?> message)
Subclasses must implement this method to provide the transformation
logic.
|
protected Object |
ClaimCheckInTransformer.doTransform(Message<?> message) |
U |
AbstractPayloadTransformer.doTransform(Message<?> message) |
protected Object |
ClaimCheckOutTransformer.doTransform(Message<?> message) |
protected Object |
ContentEnricher.handleRequestMessage(Message<?> requestMessage) |
protected Object |
MessageTransformingHandler.handleRequestMessage(Message<?> message) |
Message<?> |
MessageTransformingChannelInterceptor.postReceive(Message<?> message,
MessageChannel channel)
Deprecated.
|
Message<?> |
MessageTransformingChannelInterceptor.preSend(Message<?> message,
MessageChannel channel)
Deprecated.
|
Message<?> |
HeaderEnricher.transform(Message<?> message) |
Message<?> |
AbstractTransformer.transform(Message<?> message) |
Message<?> |
HeaderFilter.transform(Message<?> message) |
Message<?> |
Transformer.transform(Message<?> message) |
Message<?> |
AbstractMessageProcessingTransformer.transform(Message<?> message) |
Constructor and Description |
---|
MessageTransformationException(Message<?> message,
String description) |
MessageTransformationException(Message<?> message,
String description,
Throwable cause) |
MessageTransformationException(Message<?> message,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
protected void |
StatusUpdatingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
DirectMessageSendingMessageHandler.handleMessageInternal(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessagingMethodInvokerHelper.ParametersWrapper.getMessage() |
Modifier and Type | Method and Description |
---|---|
Collection<Message<?>> |
MessagingMethodInvokerHelper.ParametersWrapper.getMessages() |
Modifier and Type | Method and Description |
---|---|
protected <T> T |
AbstractExpressionEvaluator.evaluateExpression(org.springframework.expression.Expression expression,
Message<?> message,
Class<T> expectedType) |
T |
MessagingMethodInvokerHelper.process(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
T |
MessagingMethodInvokerHelper.process(Collection<Message<?>> messages,
Map<String,?> headers) |
Constructor and Description |
---|
ParametersWrapper(Message<?> message) |
Constructor and Description |
---|
ParametersWrapper(Collection<Message<?>> messages,
Map<String,?> headers) |
Modifier and Type | Method and Description |
---|---|
protected Object |
MarshallingWebServiceOutboundGateway.doHandle(String uri,
Message<?> requestMessage,
org.springframework.ws.client.core.WebServiceMessageCallback requestCallback) |
protected Object |
SimpleWebServiceOutboundGateway.doHandle(String uri,
Message<?> requestMessage,
org.springframework.ws.client.core.WebServiceMessageCallback requestCallback) |
protected abstract Object |
AbstractWebServiceOutboundGateway.doHandle(String uri,
Message<?> requestMessage,
org.springframework.ws.client.core.WebServiceMessageCallback requestCallback) |
Object |
AbstractWebServiceOutboundGateway.handleRequestMessage(Message<?> requestMessage) |
protected void |
AbstractWebServiceInboundGateway.toSoapHeaders(org.springframework.ws.WebServiceMessage response,
Message<?> replyMessage) |
Constructor and Description |
---|
RequestMessageCallback(org.springframework.ws.client.core.WebServiceMessageCallback requestCallback,
Message<?> requestMessage) |
Modifier and Type | Method and Description |
---|---|
protected List<Object> |
XPathRouter.getChannelKeys(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
boolean |
BooleanTestXPathMessageSelector.accept(Message<?> message)
Return true if the
XPathExpression evaluates to true |
boolean |
RegexTestXPathMessageSelector.accept(Message<?> message)
Evaluate the payload and return true if the value returned by the
XPathExpression matches the regex . |
boolean |
XmlValidatingMessageSelector.accept(Message<?> message) |
boolean |
StringValueTestXPathMessageSelector.accept(Message<?> message)
Evaluate the payload and return true if the value returned by the
XPathExpression is equal to the valueToTestFor . |
Modifier and Type | Method and Description |
---|---|
protected Object |
XPathMessageSplitter.splitMessage(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected Object |
XsltPayloadTransformer.doTransform(Message<?> message) |
protected Object |
XPathTransformer.doTransform(Message<?> message) |
Object |
MarshallingTransformer.doTransform(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
protected void |
ChatMessageSendingMessageHandler.handleMessageInternal(Message<?> message) |
protected void |
PresenceSendingMessageHandler.handleMessageInternal(Message<?> message) |
Copyright © 2018. All rights reserved.