Spring Integration

Uses of Interface
org.springframework.integration.Message

Packages that use Message
org.springframework.integration   
org.springframework.integration.aggregator   
org.springframework.integration.channel   
org.springframework.integration.channel.interceptor   
org.springframework.integration.core   
org.springframework.integration.dispatcher   
org.springframework.integration.endpoint   
org.springframework.integration.event   
org.springframework.integration.file   
org.springframework.integration.file.transformer   
org.springframework.integration.filter   
org.springframework.integration.ftp   
org.springframework.integration.gateway   
org.springframework.integration.groovy   
org.springframework.integration.handler   
org.springframework.integration.history   
org.springframework.integration.http   
org.springframework.integration.ip.tcp   
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   
org.springframework.integration.jdbc   
org.springframework.integration.jms   
org.springframework.integration.jmx   
org.springframework.integration.json   
org.springframework.integration.mail   
org.springframework.integration.mail.transformer   
org.springframework.integration.mapping   
org.springframework.integration.message   
org.springframework.integration.monitor   
org.springframework.integration.router   
org.springframework.integration.security.channel   
org.springframework.integration.selector   
org.springframework.integration.sftp   
org.springframework.integration.splitter   
org.springframework.integration.store   
org.springframework.integration.stream   
org.springframework.integration.support   
org.springframework.integration.support.converter   
org.springframework.integration.test.matcher   
org.springframework.integration.test.util   
org.springframework.integration.transformer   
org.springframework.integration.twitter   
org.springframework.integration.util   
org.springframework.integration.ws   
org.springframework.integration.xml.router   
org.springframework.integration.xml.selector   
org.springframework.integration.xml.splitter   
org.springframework.integration.xml.transformer   
org.springframework.integration.xmpp.messages   
org.springframework.integration.xmpp.presence   
 

Uses of Message in org.springframework.integration
 

Methods in org.springframework.integration that return Message
 Message<?> MessagingException.getFailedMessage()
           
 

Methods in org.springframework.integration with parameters of type Message
 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)
           
 

Constructors in org.springframework.integration with parameters of type Message
MessageDeliveryException(Message<?> undeliveredMessage)
           
MessageDeliveryException(Message<?> undeliveredMessage, String description)
           
MessageDeliveryException(Message<?> undeliveredMessage, String description, Throwable cause)
           
MessageHandlingException(Message<?> failedMessage)
           
MessageHandlingException(Message<?> failedMessage, String description)
           
MessageHandlingException(Message<?> failedMessage, String description, Throwable cause)
           
MessageHandlingException(Message<?> failedMessage, Throwable cause)
           
MessageRejectedException(Message<?> failedMessage)
           
MessageRejectedException(Message<?> failedMessage, String description)
           
MessageRejectedException(Message<?> failedMessage, String description, Throwable cause)
           
MessageTimeoutException(Message<?> failedMessage)
           
MessageTimeoutException(Message<?> failedMessage, String description)
           
MessageTimeoutException(Message<?> failedMessage, String description, Throwable cause)
           
MessageTimeoutException(Message<?> failedMessage, Throwable cause)
           
MessagingException(Message<?> message)
           
MessagingException(Message<?> message, String description)
           
MessagingException(Message<?> message, String description, Throwable cause)
           
MessagingException(Message<?> message, Throwable cause)
           
 

Uses of Message in org.springframework.integration.aggregator
 

Methods in org.springframework.integration.aggregator that return Message
 Message<Object> CorrelatingMessageBarrier.receive()
           
 

Methods in org.springframework.integration.aggregator with parameters of type Message
 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.
 int MessageSequenceComparator.compare(Message<?> message1, Message<?> message2)
           
 int MessageSequenceComparator.compare(Message<?> message1, Message<?> message2)
           
 Object HeaderAttributeCorrelationStrategy.getCorrelationKey(Message<?> message)
           
 Object CorrelationStrategy.getCorrelationKey(Message<?> message)
           
 Object ExpressionEvaluatingCorrelationStrategy.getCorrelationKey(Message<?> message)
           
 Object MethodInvokingCorrelationStrategy.getCorrelationKey(Message<?> message)
           
protected  void CorrelatingMessageBarrier.handleMessageInternal(Message<?> message)
           
protected  void CorrelatingMessageHandler.handleMessageInternal(Message<?> message)
           
 

Method parameters in org.springframework.integration.aggregator with type arguments of type Message
 Object MessageListProcessor.process(Collection<? extends Message<?>> messages)
           
 Object ExpressionEvaluatingMessageListProcessor.process(Collection<? extends Message<?>> messages)
          Processes the Message by evaluating the expression with that Message as the root object.
 T MethodInvokingMessageListProcessor.process(Collection<? extends Message<?>> messages, Map<String,Object> aggregateHeaders)
           
 void ResequencingMessageGroupProcessor.setComparator(Comparator<Message<?>> comparator)
          A comparator to use to order messages before processing.
 

Uses of Message in org.springframework.integration.channel
 

Methods in org.springframework.integration.channel that return Message
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<?> 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.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> ChannelInterceptor.preSend(Message<?> message, MessageChannel channel)
          Invoked before the Message is actually sent to the channel.
 Message<?> AbstractMessageChannel.ChannelInterceptorList.preSend(Message<?> message, MessageChannel 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)
           
 

Methods in org.springframework.integration.channel that return types with arguments of type Message
 List<Message<?>> QueueChannel.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.
 

Methods in org.springframework.integration.channel with parameters of type Message
protected  boolean QueueChannel.doSend(Message<?> message, long timeout)
           
protected abstract  boolean AbstractMessageChannel.doSend(Message<?> message, long timeout)
          Subclasses must implement this method.
protected  boolean AbstractSubscribableChannel.doSend(Message<?> message, long timeout)
           
protected  boolean PriorityChannel.doSend(Message<?> message, long timeout)
           
 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.postReceive(Message<?> message, MessageChannel channel)
           
 void ChannelInterceptor.postSend(Message<?> message, MessageChannel channel, boolean sent)
          Invoked immediately after the send invocation.
 void AbstractMessageChannel.ChannelInterceptorList.postSend(Message<?> message, MessageChannel channel, boolean sent)
           
 Message<?> ChannelInterceptor.preSend(Message<?> message, MessageChannel channel)
          Invoked before the Message is actually sent to the channel.
 Message<?> AbstractMessageChannel.ChannelInterceptorList.preSend(Message<?> message, MessageChannel channel)
           
 boolean NullChannel.send(Message<?> message)
           
 boolean AbstractMessageChannel.send(Message<?> message)
          Send a message on this channel.
 boolean NullChannel.send(Message<?> message, long timeout)
           
 boolean AbstractMessageChannel.send(Message<?> message, long timeout)
          Send a message on this channel.
 

Constructor parameters in org.springframework.integration.channel with type arguments of type Message
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.
 

Uses of Message in org.springframework.integration.channel.interceptor
 

Methods in org.springframework.integration.channel.interceptor that return Message
 Message<?> GlobalChannelInterceptorWrapper.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> ChannelInterceptorAdapter.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> GlobalChannelInterceptorWrapper.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> ChannelInterceptorAdapter.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> MessageSelectingInterceptor.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.
 

Methods in org.springframework.integration.channel.interceptor with parameters of type Message
 Message<?> GlobalChannelInterceptorWrapper.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> ChannelInterceptorAdapter.postReceive(Message<?> message, MessageChannel channel)
           
 void GlobalChannelInterceptorWrapper.postSend(Message<?> message, MessageChannel channel, boolean sent)
           
 void ChannelInterceptorAdapter.postSend(Message<?> message, MessageChannel channel, boolean sent)
           
 Message<?> GlobalChannelInterceptorWrapper.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> ChannelInterceptorAdapter.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> MessageSelectingInterceptor.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.
 

Uses of Message in org.springframework.integration.core
 

Methods in org.springframework.integration.core that return Message
 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)
           
 

Methods in org.springframework.integration.core that return types with arguments of type Message
 Future<Message<?>> AsyncMessagingTemplate.asyncReceive()
           
 Future<Message<?>> AsyncMessagingOperations.asyncReceive()
           
 Future<Message<?>> AsyncMessagingTemplate.asyncReceive(PollableChannel channel)
           
 Future<Message<?>> AsyncMessagingOperations.asyncReceive(PollableChannel channel)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncReceive(String channelName)
           
 Future<Message<?>> AsyncMessagingOperations.asyncReceive(String channelName)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.asyncSendAndReceive(Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(MessageChannel channel, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.asyncSendAndReceive(MessageChannel channel, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(String channelName, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.asyncSendAndReceive(String channelName, Message<?> requestMessage)
           
 

Methods in org.springframework.integration.core with parameters of type Message
 boolean MessageSelector.accept(Message<?> message)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.asyncSendAndReceive(Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(MessageChannel channel, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.asyncSendAndReceive(MessageChannel channel, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingTemplate.asyncSendAndReceive(String channelName, Message<?> requestMessage)
           
 Future<Message<?>> AsyncMessagingOperations.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)
           
 

Uses of Message in org.springframework.integration.dispatcher
 

Methods in org.springframework.integration.dispatcher with parameters of type Message
 boolean UnicastingDispatcher.dispatch(Message<?> message)
           
 boolean BroadcastingDispatcher.dispatch(Message<?> message)
           
 boolean MessageDispatcher.dispatch(Message<?> message)
           
 Iterator<MessageHandler> LoadBalancingStrategy.getHandlerIterator(Message<?> message, List<MessageHandler> handlers)
           
 Iterator<MessageHandler> RoundRobinLoadBalancingStrategy.getHandlerIterator(Message<?> message, List<MessageHandler> handlers)
          Returns an iterator that starts at a new point in the list 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.
 

Constructors in org.springframework.integration.dispatcher with parameters of type Message
AggregateMessageDeliveryException(Message<?> undeliveredMessage, String description, List<? extends Exception> aggregatedExceptions)
           
 

Uses of Message in org.springframework.integration.endpoint
 

Methods in org.springframework.integration.endpoint that return Message
 Message<Object> MethodInvokingMessageSource.receive()
           
 

Methods in org.springframework.integration.endpoint with parameters of type Message
protected  void MessageProducerSupport.sendMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.event
 

Methods in org.springframework.integration.event that return Message
 Message<?> MessagingEvent.getMessage()
           
 

Methods in org.springframework.integration.event with parameters of type Message
protected  void ApplicationEventPublishingMessageHandler.handleMessageInternal(Message<?> message)
           
 

Constructors in org.springframework.integration.event with parameters of type Message
MessagingEvent(Message<?> message)
           
 

Uses of Message in org.springframework.integration.file
 

Methods in org.springframework.integration.file that return Message
 Message<File> FileReadingMessageSource.receive()
           
 Message<File> AbstractInboundRemoteFileSystemSynchronizingMessageSource.receive()
           
 

Methods in org.springframework.integration.file with parameters of type Message
 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.
 

Uses of Message in org.springframework.integration.file.transformer
 

Methods in org.springframework.integration.file.transformer that return Message
 Message<?> AbstractFilePayloadTransformer.transform(Message<?> message)
           
 

Methods in org.springframework.integration.file.transformer with parameters of type Message
 Message<?> AbstractFilePayloadTransformer.transform(Message<?> message)
           
 

Uses of Message in org.springframework.integration.filter
 

Methods in org.springframework.integration.filter with parameters of type Message
protected  Object MessageFilter.handleRequestMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.ftp
 

Methods in org.springframework.integration.ftp with parameters of type Message
 void FtpSendingMessageHandler.handleMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.gateway
 

Methods in org.springframework.integration.gateway that return Message
 Message<?> RemotingInboundGatewaySupport.exchange(Message<?> message)
           
 Message<?> RequestReplyExchanger.exchange(Message<?> request)
           
protected  Message<?> MessagingGatewaySupport.sendAndReceiveMessage(Object object)
           
 Message<?> SimpleMessageMapper.toMessage(Object object)
          Returns a Message with the given object as its payload, unless the object is already a Message in which case it will be returned as-is.
 

Methods in org.springframework.integration.gateway with parameters of type Message
 Message<?> RemotingInboundGatewaySupport.exchange(Message<?> message)
           
 Message<?> RequestReplyExchanger.exchange(Message<?> request)
           
 Object SimpleMessageMapper.fromMessage(Message<?> message)
          Returns the Message payload (or null if the Message is null).
 Object AbstractRemotingOutboundGateway.handleRequestMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.groovy
 

Methods in org.springframework.integration.groovy with parameters of type Message
protected  Object GroovyScriptExecutingMessageProcessor.executeScript(ScriptSource scriptSource, Message<?> message)
           
 

Uses of Message in org.springframework.integration.handler
 

Methods in org.springframework.integration.handler with parameters of type Message
protected abstract  T AbstractScriptExecutingMessageProcessor.executeScript(ScriptSource scriptSource, Message<?> message)
          Subclasses must implement this method.
 void MethodInvokingMessageHandler.handleMessage(Message<?> message)
           
 void DelayHandler.handleMessage(Message<?> message)
           
 void AbstractMessageHandler.handleMessage(Message<?> message)
           
protected  void AbstractReplyProducingMessageHandler.handleMessageInternal(Message<?> message)
          
protected abstract  void AbstractMessageHandler.handleMessageInternal(Message<?> message)
           
protected  void MessageHandlerChain.handleMessageInternal(Message<?> message)
           
protected  void LoggingHandler.handleMessageInternal(Message<?> message)
           
protected abstract  Object AbstractReplyProducingMessageHandler.handleRequestMessage(Message<?> requestMessage)
          Subclasses must implement this method to handle the request Message.
protected  Object BridgeHandler.handleRequestMessage(Message<?> requestMessage)
           
protected  Object ServiceActivatingHandler.handleRequestMessage(Message<?> message)
           
 T MethodInvokingMessageProcessor.processMessage(Message<?> message)
           
abstract  T AbstractMessageProcessor.processMessage(Message<?> message)
           
 T ExpressionEvaluatingMessageProcessor.processMessage(Message<?> message)
          Processes the Message by evaluating the expression with that Message as the root object.
 T MessageProcessor.processMessage(Message<?> message)
          Process the Message and return a value (or null).
 T AbstractScriptExecutingMessageProcessor.processMessage(Message<?> message)
          Executes the script and returns the result.
 Method PayloadTypeMatchingHandlerMethodResolver.resolveHandlerMethod(Message<?> message)
           
 Method StaticHandlerMethodResolver.resolveHandlerMethod(Message<?> message)
           
 Method HandlerMethodResolver.resolveHandlerMethod(Message<?> message)
           
 

Uses of Message in org.springframework.integration.history
 

Methods in org.springframework.integration.history that return Message
 Message<?> HistoryWritingMessagePostProcessor.postProcessMessage(Message<?> message)
           
static
<T> Message<T>
MessageHistory.write(Message<T> message, NamedComponent component)
           
 

Methods in org.springframework.integration.history with parameters of type Message
 Message<?> HistoryWritingMessagePostProcessor.postProcessMessage(Message<?> message)
           
static MessageHistory MessageHistory.read(Message<?> message)
           
static
<T> Message<T>
MessageHistory.write(Message<T> message, NamedComponent component)
           
 

Uses of Message in org.springframework.integration.http
 

Methods in org.springframework.integration.http that return Message
 Message<?> DefaultInboundRequestMapper.toMessage(javax.servlet.http.HttpServletRequest request)
           
 Message<?> DataBindingInboundRequestMapper.toMessage(javax.servlet.http.HttpServletRequest request)
           
 

Methods in org.springframework.integration.http with parameters of type Message
protected  Object HttpRequestExecutingMessageHandler.handleRequestMessage(Message<?> requestMessage)
           
 

Uses of Message in org.springframework.integration.ip.tcp
 

Methods in org.springframework.integration.ip.tcp with parameters of type Message
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)
           
 boolean TcpOutboundGateway.onMessage(Message<?> message)
           
 boolean TcpInboundGateway.onMessage(Message<?> message)
           
 boolean TcpReceivingChannelAdapter.onMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.ip.tcp.connection
 

Methods in org.springframework.integration.ip.tcp.connection that return Message
 Message<Object> TcpMessageMapper.toMessage(TcpConnection connection)
           
 

Methods in org.springframework.integration.ip.tcp.connection with parameters of type Message
 Object TcpMessageMapper.fromMessage(Message<?> message)
           
 boolean TcpListener.onMessage(Message<?> message)
          Called by a TCPConnection when a new message arrives.
 boolean AbstractTcpConnectionInterceptor.onMessage(Message<?> message)
           
 void AbstractTcpConnectionInterceptor.send(Message<?> message)
           
 void TcpNioConnection.send(Message<?> message)
           
 void TcpConnection.send(Message<?> message)
          Converts and sends the message.
 void TcpNetConnection.send(Message<?> message)
           
 

Uses of Message in org.springframework.integration.ip.udp
 

Methods in org.springframework.integration.ip.udp that return Message
 Message<byte[]> DatagramPacketMessageMapper.toMessage(DatagramPacket packet)
           
 

Methods in org.springframework.integration.ip.udp with parameters of type Message
 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)
           
 

Uses of Message in org.springframework.integration.jdbc
 

Methods in org.springframework.integration.jdbc that return Message
<T> Message<T>
JdbcMessageStore.addMessage(Message<T> message)
           
 Message<?> JdbcMessageStore.getMessage(UUID id)
           
 Message<Object> JdbcPollingChannelAdapter.receive()
          Executes the query.
 Message<?> JdbcMessageStore.removeMessage(UUID id)
           
 

Methods in org.springframework.integration.jdbc with parameters of type Message
<T> Message<T>
JdbcMessageStore.addMessage(Message<T> message)
           
 MessageGroup JdbcMessageStore.addMessageToGroup(Object groupId, Message<?> message)
           
protected  void JdbcMessageHandler.handleMessageInternal(Message<?> message)
          Executes the update, passing the message into the SqlParameterSourceFactory.
protected  Object JdbcOutboundGateway.handleRequestMessage(Message<?> requestMessage)
           
 MessageGroup JdbcMessageStore.removeMessageFromGroup(Object groupId, Message<?> messageToMark)
           
 

Method parameters in org.springframework.integration.jdbc with type arguments of type Message
 void JdbcMessageStore.setDeserializer(org.springframework.commons.serializer.InputStreamingConverter<? super Message<?>> deserializer)
          A converter for deserializing byte arrays to messages.
 void JdbcMessageStore.setSerializer(org.springframework.commons.serializer.OutputStreamingConverter<? super Message<?>> serializer)
          A converter for serializing messages to byte arrays for storage.
 

Uses of Message in org.springframework.integration.jms
 

Methods in org.springframework.integration.jms that return Message
 Message<Object> JmsDestinationPollingSource.receive()
          Will receive a JMS Message converting and returning it as a Spring Integration Message.
 

Methods in org.springframework.integration.jms with parameters of type Message
 void JmsSendingMessageHandler.handleMessage(Message<?> message)
           
protected  Object JmsOutboundGateway.handleRequestMessage(Message<?> message)
           
 boolean JmsDestinationBackedMessageChannel.send(Message<?> message)
           
 boolean JmsDestinationBackedMessageChannel.send(Message<?> message, long timeout)
           
 

Uses of Message in org.springframework.integration.jmx
 

Methods in org.springframework.integration.jmx that return Message
 Message<?> AttributePollingMessageSource.receive()
          Retrieves the attribute value and returns it in the payload of a Message.
 

Methods in org.springframework.integration.jmx with parameters of type Message
protected  void NotificationPublishingMessageHandler.handleMessageInternal(Message<?> message)
           
protected  Object OperationInvokingMessageHandler.handleRequestMessage(Message<?> requestMessage)
           
 

Uses of Message in org.springframework.integration.json
 

Methods in org.springframework.integration.json that return Message
 Message<?> InboundJsonMessageMapper.toMessage(String jsonMessage)
           
 

Methods in org.springframework.integration.json with parameters of type Message
 String OutboundJsonMessageMapper.fromMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.mail
 

Methods in org.springframework.integration.mail that return Message
 Message<javax.mail.Message> MailReceivingMessageSource.receive()
           
 

Methods in org.springframework.integration.mail with parameters of type Message
protected  void MailSendingMessageHandler.handleMessageInternal(Message<?> message)
           
 

Uses of Message in org.springframework.integration.mail.transformer
 

Methods in org.springframework.integration.mail.transformer that return Message
 Message<?> AbstractMailMessageTransformer.transform(Message<?> message)
           
 

Methods in org.springframework.integration.mail.transformer with parameters of type Message
 Message<?> AbstractMailMessageTransformer.transform(Message<?> message)
           
 

Uses of Message in org.springframework.integration.mapping
 

Methods in org.springframework.integration.mapping that return Message
 Message<?> InboundMessageMapper.toMessage(T object)
           
 

Methods in org.springframework.integration.mapping with parameters of type Message
 T OutboundMessageMapper.fromMessage(Message<?> message)
           
 

Constructors in org.springframework.integration.mapping with parameters of type Message
MessageMappingException(Message<?> failedMessage, String description)
           
MessageMappingException(Message<?> failedMessage, String description, Throwable cause)
           
 

Uses of Message in org.springframework.integration.message
 

Classes in org.springframework.integration.message that implement Message
 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.
 

Uses of Message in org.springframework.integration.monitor
 

Methods in org.springframework.integration.monitor with parameters of type Message
 void SimpleMessageHandlerMonitor.handleMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.router
 

Methods in org.springframework.integration.router with parameters of type Message
 boolean RecipientListRouter.Recipient.accept(Message<?> message)
           
protected  MessageChannel PayloadTypeRouter.determineTargetChannel(Message<?> message)
           
protected  MessageChannel ErrorMessageExceptionTypeRouter.determineTargetChannel(Message<?> message)
           
protected abstract  MessageChannel AbstractSingleChannelRouter.determineTargetChannel(Message<?> message)
          Subclasses must implement this method to return the target channel.
protected abstract  String AbstractSingleChannelNameRouter.determineTargetChannelName(Message<?> message)
          Subclasses must implement this method to return the channel name.
protected  Collection<MessageChannel> AbstractChannelNameResolvingMessageRouter.determineTargetChannels(Message<?> message)
           
protected abstract  Collection<MessageChannel> AbstractMessageRouter.determineTargetChannels(Message<?> message)
          Subclasses must implement this method to return the target channels for a given Message.
protected  Collection<MessageChannel> AbstractSingleChannelRouter.determineTargetChannels(Message<?> message)
           
protected  Collection<MessageChannel> RecipientListRouter.determineTargetChannels(Message<?> message)
           
protected abstract  List<Object> AbstractChannelNameResolvingMessageRouter.getChannelIndicatorList(Message<?> message)
          Subclasses must implement this method to return the channel indicators.
protected  List<Object> AbstractSingleChannelNameRouter.getChannelIndicatorList(Message<?> message)
           
protected  List<Object> HeaderValueRouter.getChannelIndicatorList(Message<?> message)
           
protected  void AbstractMessageRouter.handleMessageInternal(Message<?> message)
           
 

Uses of Message in org.springframework.integration.security.channel
 

Methods in org.springframework.integration.security.channel that return Message
 Message<?> ChannelInvocation.getMessage()
           
 

Uses of Message in org.springframework.integration.selector
 

Methods in org.springframework.integration.selector with parameters of type Message
 boolean UnexpiredMessageSelector.accept(Message<?> message)
           
 boolean PayloadTypeSelector.accept(Message<?> message)
           
 boolean MessageSelectorChain.accept(Message<?> message)
          Pass the message through the selector chain.
 

Uses of Message in org.springframework.integration.sftp
 

Methods in org.springframework.integration.sftp with parameters of type Message
 void SftpSendingMessageHandler.handleMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.splitter
 

Methods in org.springframework.integration.splitter with parameters of type Message
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.
 

Uses of Message in org.springframework.integration.store
 

Fields in org.springframework.integration.store with type parameters of type Message
 BlockingQueue<Message<?>> SimpleMessageGroup.marked
           
 BlockingQueue<Message<?>> SimpleMessageGroup.unmarked
           
 

Methods in org.springframework.integration.store that return Message
<T> Message<T>
MessageStore.addMessage(Message<T> message)
          Put the provided Message into the MessageStore.
<T> Message<T>
SimpleMessageStore.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<?> SimpleMessageGroup.getOne()
           
 Message<?> MessageGroup.getOne()
           
 Message<?> MessageGroupQueue.peek()
           
 Message<?> MessageGroupQueue.poll()
           
 Message<?> MessageGroupQueue.poll(long timeout, TimeUnit unit)
           
 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<?> MessageGroupQueue.take()
           
 

Methods in org.springframework.integration.store that return types with arguments of type Message
 Collection<Message<?>> SimpleMessageGroup.getMarked()
           
 Collection<Message<?>> MessageGroup.getMarked()
           
 Collection<Message<?>> SimpleMessageGroup.getUnmarked()
           
 Collection<Message<?>> MessageGroup.getUnmarked()
           
 Iterator<Message<?>> MessageGroupQueue.iterator()
           
 

Methods in org.springframework.integration.store with parameters of type Message
 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)
           
 MessageGroup MessageGroupStore.addMessageToGroup(Object groupId, Message<?> message)
          Store a message with an association to a group id.
 MessageGroup SimpleMessageStore.addMessageToGroup(Object groupId, Message<?> message)
           
 boolean SimpleMessageGroup.canAdd(Message<?> message)
           
 boolean MessageGroup.canAdd(Message<?> message)
          Query if the message can be added.
 void SimpleMessageGroup.mark(Message<?> messageToMark)
           
 boolean MessageGroupQueue.offer(Message<?> e)
           
 boolean MessageGroupQueue.offer(Message<?> e, long timeout, TimeUnit unit)
           
 void MessageGroupQueue.put(Message<?> e)
           
 void SimpleMessageGroup.remove(Message<?> message)
           
 MessageGroup MessageGroupStore.removeMessageFromGroup(Object key, Message<?> messageToMark)
          Persist a mark on a single message from the group.
 MessageGroup SimpleMessageStore.removeMessageFromGroup(Object key, Message<?> messageToMark)
           
 

Method parameters in org.springframework.integration.store with type arguments of type Message
 int MessageGroupQueue.drainTo(Collection<? super Message<?>> c)
           
 int MessageGroupQueue.drainTo(Collection<? super Message<?>> c, int maxElements)
           
 

Constructor parameters in org.springframework.integration.store with type arguments of type Message
SimpleMessageGroup(Collection<? extends Message<?>> unmarked, Collection<? extends Message<?>> marked, Object groupId, long timestamp)
           
SimpleMessageGroup(Collection<? extends Message<?>> unmarked, Collection<? extends Message<?>> marked, Object groupId, long timestamp)
           
SimpleMessageGroup(Collection<? extends Message<?>> unmarked, Object groupId)
           
 

Uses of Message in org.springframework.integration.stream
 

Methods in org.springframework.integration.stream that return Message
 Message<String> CharacterStreamReadingMessageSource.receive()
           
 Message<byte[]> ByteStreamReadingMessageSource.receive()
           
 

Methods in org.springframework.integration.stream with parameters of type Message
protected  void ByteStreamWritingMessageHandler.handleMessageInternal(Message<?> message)
           
protected  void CharacterStreamWritingMessageHandler.handleMessageInternal(Message<?> message)
           
 

Uses of Message in org.springframework.integration.support
 

Methods in org.springframework.integration.support that return Message
 Message<T> MessageBuilder.build()
           
 

Methods in org.springframework.integration.support with parameters of type Message
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.
 

Uses of Message in org.springframework.integration.support.converter
 

Methods in org.springframework.integration.support.converter that return Message
<P> Message<P>
SimpleMessageConverter.toMessage(Object object)
           
<P> Message<P>
MessageConverter.toMessage(Object object)
           
 

Methods in org.springframework.integration.support.converter with parameters of type Message
<P> Object
SimpleMessageConverter.fromMessage(Message<P> message)
           
<P> Object
MessageConverter.fromMessage(Message<P> message)
           
 

Constructors in org.springframework.integration.support.converter with parameters of type Message
MessageConversionException(Message<?> failedMessage, String description, Throwable cause)
           
 

Uses of Message in org.springframework.integration.test.matcher
 

Methods in org.springframework.integration.test.matcher that return Message
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)
           
 

Methods in org.springframework.integration.test.matcher that return types with arguments of type Message
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<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)
           
 

Methods in org.springframework.integration.test.matcher with parameters of type Message
 boolean HeaderMatcher.matchesSafely(Message<?> item)
          Subclasses should implement this.
 boolean PayloadMatcher.matchesSafely(Message<?> message)
          Subclasses should implement this.
static org.hamcrest.Matcher<Message<?>> PayloadAndHeaderMatcher.sameExceptIgnorableHeaders(Message<?> expected, String... ignoreKeys)
           
 

Uses of Message in org.springframework.integration.test.util
 

Method parameters in org.springframework.integration.test.util with type arguments of type Message
static MessageHandler TestUtils.handlerExpecting(org.hamcrest.Matcher<Message> messageMatcher)
           
 

Uses of Message in org.springframework.integration.transformer
 

Methods in org.springframework.integration.transformer that return Message
 Message<?> MessageTransformingChannelInterceptor.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> MessageTransformingChannelInterceptor.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> HeaderEnricher.transform(Message<?> message)
           
 Message<?> AbstractTransformer.transform(Message<?> message)
           
 Message<?> Transformer.transform(Message<?> message)
           
 Message<?> AbstractMessageProcessingTransformer.transform(Message<?> message)
           
 Message<?> HeaderFilter.transform(Message<?> message)
           
 

Methods in org.springframework.integration.transformer with parameters of type Message
protected abstract  Object AbstractTransformer.doTransform(Message<?> message)
          Subclasses must implement this method to provide the transformation logic.
protected  Object ClaimCheckOutTransformer.doTransform(Message<?> message)
           
protected  Object ClaimCheckInTransformer.doTransform(Message<?> message)
           
 U AbstractPayloadTransformer.doTransform(Message<?> message)
           
protected  Object MessageTransformingHandler.handleRequestMessage(Message<?> message)
           
 Message<?> MessageTransformingChannelInterceptor.postReceive(Message<?> message, MessageChannel channel)
           
 Message<?> MessageTransformingChannelInterceptor.preSend(Message<?> message, MessageChannel channel)
           
 Message<?> HeaderEnricher.transform(Message<?> message)
           
 Message<?> AbstractTransformer.transform(Message<?> message)
           
 Message<?> Transformer.transform(Message<?> message)
           
 Message<?> AbstractMessageProcessingTransformer.transform(Message<?> message)
           
 Message<?> HeaderFilter.transform(Message<?> message)
           
 

Constructors in org.springframework.integration.transformer with parameters of type Message
MessageTransformationException(Message<?> message, String description)
           
MessageTransformationException(Message<?> message, String description, Throwable cause)
           
MessageTransformationException(Message<?> message, Throwable cause)
           
 

Uses of Message in org.springframework.integration.twitter
 

Methods in org.springframework.integration.twitter with parameters of type Message
 twitter4j.StatusUpdate StatusUpdateSupport.fromMessage(Message<?> message)
          StatusUpdate instances are used to drive status updates.
 void OutboundUpdatedStatusMessageHandler.handleMessage(Message<?> message)
           
 void OutboundDMStatusMessageHandler.handleMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.util
 

Methods in org.springframework.integration.util with parameters of type Message
protected
<T> T
AbstractExpressionEvaluator.evaluateExpression(Expression expression, Message<?> message, Class<T> expectedType)
           
 T MessagingMethodInvokerHelper.process(Message<?> message)
           
 

Method parameters in org.springframework.integration.util with type arguments of type Message
 T MessagingMethodInvokerHelper.process(Collection<Message<?>> messages, Map<String,?> headers)
           
 

Uses of Message in org.springframework.integration.ws
 

Methods in org.springframework.integration.ws with parameters of type Message
 Object AbstractWebServiceOutboundGateway.handleRequestMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.xml.router
 

Methods in org.springframework.integration.xml.router with parameters of type Message
protected  String XmlPayloadValidatingRouter.determineTargetChannelName(Message<?> message)
           
 List<Object> XPathMultiChannelRouter.getChannelIndicatorList(Message<?> message)
           
protected  List<Object> XPathSingleChannelRouter.getChannelIndicatorList(Message<?> message)
          Evaluates the payload using XPathExpression.evaluateAsString(Node)
 

Uses of Message in org.springframework.integration.xml.selector
 

Methods in org.springframework.integration.xml.selector with parameters of type Message
 boolean BooleanTestXPathMessageSelector.accept(Message<?> message)
          Return true if the XPathExpression evaluates to true
 boolean StringValueTestXPathMessageSelector.accept(Message<?> message)
          Evaluate the payload and return true if the value returned by the XPathExpression is equal to the valueToTestFor.
 

Uses of Message in org.springframework.integration.xml.splitter
 

Methods in org.springframework.integration.xml.splitter with parameters of type Message
protected  Object XPathMessageSplitter.splitMessage(Message<?> message)
           
protected  List<Node> XPathMessageSplitter.splitNodePayload(Node node, Message message)
           
 

Uses of Message in org.springframework.integration.xml.transformer
 

Methods in org.springframework.integration.xml.transformer with parameters of type Message
protected  Transformer XsltPayloadTransformer.buildTransformer(Message<?> message)
           
 Object MarshallingTransformer.doTransform(Message<?> message)
           
protected  Object XPathTransformer.doTransform(Message<?> message)
           
protected  Object XsltPayloadTransformer.doTransform(Message<?> message)
           
 Object XPathHeaderEnricher.XPathExpressionEvaluatingHeaderValueMessageProcessor.processMessage(Message<?> message)
           
 

Uses of Message in org.springframework.integration.xmpp.messages
 

Methods in org.springframework.integration.xmpp.messages with parameters of type Message
protected  void XmppMessageSendingMessageHandler.handleMessageInternal(Message<?> message)
           
 

Uses of Message in org.springframework.integration.xmpp.presence
 

Methods in org.springframework.integration.xmpp.presence that return Message
 Message<?> XmppPresenceMessageMapper.toMessage(org.jivesoftware.smack.packet.Presence presence)
          Returns a Message with payload Presence
 

Methods in org.springframework.integration.xmpp.presence with parameters of type Message
 org.jivesoftware.smack.packet.Presence XmppPresenceMessageMapper.fromMessage(Message<?> message)
          Builds a Presence object from the inbound Message headers, if possible.
protected  void XmppRosterEventMessageSendingHandler.handleMessageInternal(Message<?> message)
           
 


Spring Integration

Copyright © 2010. All Rights Reserved.