Uses of Interface
org.springframework.messaging.Message
Package
Description
Core package of the JMS support.
Message listener adapter mechanism that delegates to target listener
methods, converting messages to appropriate message content types
(such as String or byte array) that get passed into listener methods.
This package provides generic JMS support classes,
to be used by higher-level classes like JmsTemplate.
Support for working with messaging APIs and protocols.
Provides support for message conversion.
Defines interfaces and implementation classes for messaging templates.
Basic abstractions for working with message handler methods.
Support classes for working with annotated message-handling methods with
non-blocking, reactive contracts.
Support classes for working with annotated message-handling methods.
Common infrastructure for invoking message handler methods.
Common infrastructure for invoking message handler methods with non-blocking,
and reactive contracts.
Support classes for working with annotated RSocket stream handling methods.
Generic support for Simple Messaging Protocols including protocols such as STOMP.
Support classes for handling messages from simple messaging protocols
(like STOMP).
Provides a "simple" message broker implementation along with an abstract base
class and other supporting types such as a registry for subscriptions.
Generic support for simple messaging protocols (like STOMP).
Support for handling messages to "user" destinations (i.e.
Provides implementations of
Message
along with
a MessageBuilder and MessageHeaderAccessor for building and working with messages and
message headers, as well as various MessageChannel
implementations and channel interceptor support.Contains abstractions and implementation classes for establishing TCP connections via
TcpOperations
,
handling messages via
TcpConnectionHandler
,
as well as sending messages via
TcpConnection
.Contains support for TCP messaging based on Reactor.
WebSocket integration for Spring's messaging module.
-
Uses of Message in org.springframework.jms.core
Modifier and TypeMethodDescriptionprotected Message<?>
JmsMessagingTemplate.convertJmsMessage
(Message message) protected Message<?>
JmsMessagingTemplate.doReceive
(Destination destination) protected Message<?>
protected Message<?>
JmsMessagingTemplate.doSendAndReceive
(Destination destination, Message<?> requestMessage) protected Message<?>
JmsMessagingTemplate.doSendAndReceive
(String destinationName, Message<?> requestMessage) Message<?>
Receive a message from the given destination.Message<?>
JmsMessagingTemplate.receive()
Message<?>
Message<?>
JmsMessageOperations.sendAndReceive
(String destinationName, Message<?> requestMessage) Send a request message and receive the reply from the given destination.Message<?>
JmsMessagingTemplate.sendAndReceive
(String destinationName, Message<?> requestMessage) Message<?>
JmsMessagingTemplate.sendAndReceive
(Message<?> requestMessage) Modifier and TypeMethodDescriptionprotected void
JmsMessagingTemplate.doSend
(Destination destination, Message<?> message) protected void
protected Message<?>
JmsMessagingTemplate.doSendAndReceive
(Destination destination, Message<?> requestMessage) protected Message<?>
JmsMessagingTemplate.doSendAndReceive
(String destinationName, Message<?> requestMessage) void
Send a message to the given destination.void
void
Message<?>
JmsMessageOperations.sendAndReceive
(String destinationName, Message<?> requestMessage) Send a request message and receive the reply from the given destination.Message<?>
JmsMessagingTemplate.sendAndReceive
(String destinationName, Message<?> requestMessage) Message<?>
JmsMessagingTemplate.sendAndReceive
(Message<?> requestMessage) -
Uses of Message in org.springframework.jms.listener.adapter
Modifier and TypeMethodDescriptionprotected Message<?>
MessagingMessageListenerAdapter.toMessagingMessage
(Message jmsMessage) -
Uses of Message in org.springframework.jms.support
Modifier and TypeMethodDescriptionstatic JmsMessageHeaderAccessor
Create aJmsMessageHeaderAccessor
from the headers of an existing message. -
Uses of Message in org.springframework.messaging
Modifier and TypeMethodDescriptionMessage<?>
MessagingException.getFailedMessage()
Message<?>
PollableChannel.receive()
Receive a message from this channel, blocking indefinitely if necessary.Message<?>
PollableChannel.receive
(long timeout) Receive a message from this channel, blocking until either a message is available or the specified timeout period elapses.Modifier and TypeMethodDescriptionvoid
MessageHandler.handleMessage
(Message<?> message) Handle the given message.reactor.core.publisher.Mono<Void>
ReactiveMessageHandler.handleMessage
(Message<?> message) Handle the given message.default boolean
Send aMessage
to this channel.boolean
Send a message, blocking until either the message is accepted or the specified timeout period elapses.ModifierConstructorDescriptionMessageDeliveryException
(Message<?> undeliveredMessage) MessageDeliveryException
(Message<?> undeliveredMessage, String description) MessageDeliveryException
(Message<?> undeliveredMessage, String description, Throwable cause) MessageDeliveryException
(Message<?> message, Throwable cause) MessageHandlingException
(Message<?> failedMessage) MessageHandlingException
(Message<?> message, String description) MessageHandlingException
(Message<?> message, String description, Throwable cause) MessageHandlingException
(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.messaging.converter
Modifier and TypeMethodDescriptionfinal Message<?>
AbstractMessageConverter.toMessage
(Object payload, MessageHeaders headers) final Message<?>
AbstractMessageConverter.toMessage
(Object payload, MessageHeaders headers, Object conversionHint) Message<?>
CompositeMessageConverter.toMessage
(Object payload, MessageHeaders headers) Message<?>
CompositeMessageConverter.toMessage
(Object payload, MessageHeaders headers, Object conversionHint) Message<?>
MessageConverter.toMessage
(Object payload, MessageHeaders headers) Create aMessage
whose payload is the result of converting the given payload Object to serialized form.Message<?>
SimpleMessageConverter.toMessage
(Object payload, MessageHeaders headers) Message<?>
SmartMessageConverter.toMessage
(Object payload, MessageHeaders headers, Object conversionHint) A variant ofMessageConverter.toMessage(Object, MessageHeaders)
which takes an extra conversion context as an argument, allowing to take, for example, annotations on a return type into account.Modifier and TypeMethodDescriptionprotected boolean
AbstractMessageConverter.canConvertFrom
(Message<?> message, Class<?> targetClass) protected boolean
MappingJackson2MessageConverter.canConvertFrom
(Message<?> message, Class<?> targetClass) protected boolean
MarshallingMessageConverter.canConvertFrom
(Message<?> message, Class<?> targetClass) protected Object
AbstractJsonMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) protected Object
AbstractMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) Convert the message payload from serialized form to an Object.protected Object
ByteArrayMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) protected Object
MappingJackson2MessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) protected Object
MarshallingMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) protected Object
ProtobufMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) protected Object
StringMessageConverter.convertFromInternal
(Message<?> message, Class<?> targetClass, Object conversionHint) final Object
AbstractMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass) final Object
AbstractMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass, Object conversionHint) CompositeMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass) CompositeMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass, Object conversionHint) GenericMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass) MessageConverter.fromMessage
(Message<?> message, Class<?> targetClass) Convert the payload of aMessage
from a serialized form to a typed Object of the specified target class.SimpleMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass) SmartMessageConverter.fromMessage
(Message<?> message, Class<?> targetClass, Object conversionHint) A variant ofMessageConverter.fromMessage(Message, Class)
which takes an extra conversion context as an argument, allowing to take, for example, annotations on a payload parameter into account.ModifierConstructorDescriptionMessageConversionException
(Message<?> failedMessage, String description) MessageConversionException
(Message<?> failedMessage, String description, Throwable cause) -
Uses of Message in org.springframework.messaging.core
Modifier and TypeMethodDescriptionprotected Message<?>
AbstractMessageSendingTemplate.doConvert
(Object payload, Map<String, Object> headers, MessagePostProcessor postProcessor) Convert the given Object to serialized form, possibly using aMessageConverter
, wrap it as a message with the given headers and apply the given post processor.protected abstract Message<?>
Actually receive a message from the given destination.protected final Message<?>
GenericMessagingTemplate.doReceive
(MessageChannel channel) protected final Message<?>
GenericMessagingTemplate.doReceive
(MessageChannel channel, long timeout) protected abstract Message<?>
AbstractMessagingTemplate.doSendAndReceive
(D destination, Message<?> requestMessage) protected final Message<?>
GenericMessagingTemplate.doSendAndReceive
(MessageChannel channel, Message<?> requestMessage) Message<?>
MessagePostProcessor.postProcessMessage
(Message<?> message) Process the given message.Message<?>
Message<?>
AbstractMessageReceivingTemplate.receive()
Message<?>
Message<?>
Resolve the given destination name and receive a message from it.Message<?>
MessageReceivingOperations.receive()
Receive a message from a default destination.Message<?>
Receive a message from the given destination.Message<?>
AbstractDestinationResolvingMessagingTemplate.sendAndReceive
(String destinationName, Message<?> requestMessage) Message<?>
AbstractMessagingTemplate.sendAndReceive
(D destination, Message<?> requestMessage) Message<?>
AbstractMessagingTemplate.sendAndReceive
(Message<?> requestMessage) Message<?>
DestinationResolvingMessageRequestReplyOperations.sendAndReceive
(String destinationName, Message<?> requestMessage) Resolve the given destination name to a destination and send the given message, receive a reply and return it.Message<?>
MessageRequestReplyOperations.sendAndReceive
(D destination, Message<?> requestMessage) Send a request message and receive the reply from the given destination.Message<?>
MessageRequestReplyOperations.sendAndReceive
(Message<?> requestMessage) Send a request message and receive the reply from a default destination.Modifier and TypeMethodDescriptionprotected <T> T
Convert from the given message to the given target class.protected abstract void
protected final void
GenericMessagingTemplate.doSend
(MessageChannel channel, Message<?> message) protected final void
GenericMessagingTemplate.doSend
(MessageChannel channel, Message<?> message, long timeout) protected abstract Message<?>
AbstractMessagingTemplate.doSendAndReceive
(D destination, Message<?> requestMessage) protected final Message<?>
GenericMessagingTemplate.doSendAndReceive
(MessageChannel channel, Message<?> requestMessage) Message<?>
MessagePostProcessor.postProcessMessage
(Message<?> message) Process the given message.void
void
void
void
Resolve the given destination name to a destination and send a message to it.void
Send a message to the given destination.void
Send a message to a default destination.Message<?>
AbstractDestinationResolvingMessagingTemplate.sendAndReceive
(String destinationName, Message<?> requestMessage) Message<?>
AbstractMessagingTemplate.sendAndReceive
(D destination, Message<?> requestMessage) Message<?>
AbstractMessagingTemplate.sendAndReceive
(Message<?> requestMessage) Message<?>
DestinationResolvingMessageRequestReplyOperations.sendAndReceive
(String destinationName, Message<?> requestMessage) Resolve the given destination name to a destination and send the given message, receive a reply and return it.Message<?>
MessageRequestReplyOperations.sendAndReceive
(D destination, Message<?> requestMessage) Send a request message and receive the reply from the given destination.Message<?>
MessageRequestReplyOperations.sendAndReceive
(Message<?> requestMessage) Send a request message and receive the reply from a default destination. -
Uses of Message in org.springframework.messaging.handler
Modifier and TypeMethodDescriptionint
CompositeMessageCondition.compareTo
(CompositeMessageCondition other, Message<?> message) int
DestinationPatternsMessageCondition.compareTo
(DestinationPatternsMessageCondition other, Message<?> message) Compare the two conditions based on the destination patterns they contain.int
Compare this condition to another in the context of a specific message.CompositeMessageCondition.getMatchingCondition
(Message<?> message) DestinationPatternsMessageCondition.getMatchingCondition
(Message<?> message) Check if any of the patterns match the given Message destination and return an instance that is guaranteed to contain matching patterns, sorted viaPathMatcher.getPatternComparator(String)
.MessageCondition.getMatchingCondition
(Message<?> message) Check if this condition matches the given Message and returns a potentially new condition with content tailored to the current message. -
Uses of Message in org.springframework.messaging.handler.annotation.reactive
Modifier and TypeMethodDescriptionprotected RouteMatcher.Route
MessageMappingMessageHandler.getDestination
(Message<?> message) protected Comparator<CompositeMessageCondition>
MessageMappingMessageHandler.getMappingComparator
(Message<?> message) protected CompositeMessageCondition
MessageMappingMessageHandler.getMatchingMapping
(CompositeMessageCondition mapping, Message<?> message) protected MimeType
PayloadMethodArgumentResolver.getMimeType
(Message<?> message) Return the mime type for the content.protected reactor.core.publisher.Mono<Void>
MessageMappingMessageHandler.handleMatch
(CompositeMessageCondition mapping, HandlerMethod handlerMethod, Message<?> message) protected abstract void
AbstractNamedValueMethodArgumentResolver.handleMissingValue
(String name, MethodParameter parameter, Message<?> message) Invoked when a value is required, butAbstractNamedValueMethodArgumentResolver.resolveArgumentInternal(org.springframework.core.MethodParameter, org.springframework.messaging.Message<?>, java.lang.String)
returnednull
and there is no default value.protected void
DestinationVariableMethodArgumentResolver.handleMissingValue
(String name, MethodParameter parameter, Message<?> message) protected void
HeaderMethodArgumentResolver.handleMissingValue
(String headerName, MethodParameter parameter, Message<?> message) reactor.core.publisher.Mono<Object>
ContinuationHandlerMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) final reactor.core.publisher.Mono<Object>
PayloadMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) Decode the content of the given message payload through a compatibleDecoder
.protected abstract Object
AbstractNamedValueMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) Resolves the given parameter type and value name into an argument value.protected Object
DestinationVariableMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) protected Object
HeaderMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) AbstractNamedValueMethodArgumentResolver.resolveArgumentValue
(MethodParameter parameter, Message<?> message) HeadersMethodArgumentResolver.resolveArgumentValue
(MethodParameter parameter, Message<?> message) -
Uses of Message in org.springframework.messaging.handler.annotation.support
Modifier and TypeMethodDescriptionprotected Class<?>
MessageMethodArgumentResolver.getPayloadType
(MethodParameter parameter, Message<?> message) Resolve the target class to convert the payload to.protected abstract void
AbstractNamedValueMethodArgumentResolver.handleMissingValue
(String name, MethodParameter parameter, Message<?> message) Invoked when a value is required, butAbstractNamedValueMethodArgumentResolver.resolveArgumentInternal(org.springframework.core.MethodParameter, org.springframework.messaging.Message<?>, java.lang.String)
returnednull
and there is no default value.protected void
DestinationVariableMethodArgumentResolver.handleMissingValue
(String name, MethodParameter parameter, Message<?> message) protected void
HeaderMethodArgumentResolver.handleMissingValue
(String headerName, MethodParameter parameter, Message<?> message) protected void
AbstractNamedValueMethodArgumentResolver.handleResolvedValue
(Object arg, String name, MethodParameter parameter, Message<?> message) Invoked after a value is resolved.AbstractNamedValueMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) HeadersMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) MessageMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) PayloadMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) protected abstract Object
AbstractNamedValueMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) Resolves the given parameter type and value name into an argument value.protected Object
DestinationVariableMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) protected Object
HeaderMethodArgumentResolver.resolveArgumentInternal
(MethodParameter parameter, Message<?> message, String name) protected Class<?>
PayloadMethodArgumentResolver.resolveTargetClass
(MethodParameter parameter, Message<?> message) Resolve the target class to convert the payload to.protected void
PayloadMethodArgumentResolver.validate
(Message<?> message, MethodParameter parameter, Object target) Validate the payload if applicable.ModifierConstructorDescriptionMethodArgumentNotValidException
(Message<?> message, MethodParameter parameter) Create a new instance with the invalidMethodParameter
.MethodArgumentNotValidException
(Message<?> message, MethodParameter parameter, BindingResult bindingResult) Create a new instance with the invalidMethodParameter
and aBindingResult
.MethodArgumentTypeMismatchException
(Message<?> message, MethodParameter parameter, String description) -
Uses of Message in org.springframework.messaging.handler.invocation
Modifier and TypeMethodDescriptionprotected abstract String
AbstractMethodMessageHandler.getDestination
(Message<?> message) protected abstract Comparator<T>
AbstractMethodMessageHandler.getMappingComparator
(Message<?> message) Return a comparator for sorting matching mappings.protected abstract T
AbstractMethodMessageHandler.getMatchingMapping
(T mapping, Message<?> message) Check if a mapping matches the current message and return a possibly new mapping with conditions relevant to the current request.protected Object[]
InvocableHandlerMethod.getMethodArgumentValues
(Message<?> message, Object... providedArgs) Get the method argument values for the current message, checking the provided argument values and falling back to the configured argument resolvers.protected void
AbstractMethodMessageHandler.handleMatch
(T mapping, HandlerMethod handlerMethod, String lookupDestination, Message<?> message) void
AbstractMethodMessageHandler.handleMessage
(Message<?> message) protected void
AbstractMethodMessageHandler.handleMessageInternal
(Message<?> message, String lookupDestination) protected void
AbstractMethodMessageHandler.handleNoMatch
(Set<T> ts, String lookupDestination, Message<?> message) void
AbstractAsyncReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) void
HandlerMethodReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) Handle the given return value.void
HandlerMethodReturnValueHandlerComposite.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) Invoke the method after resolving its argument values in the context of the given message.protected void
AbstractMethodMessageHandler.processHandlerMethodException
(HandlerMethod handlerMethod, Exception exception, Message<?> message) HandlerMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) Resolves a method parameter into an argument value from a given message.HandlerMethodArgumentResolverComposite.resolveArgument
(MethodParameter parameter, Message<?> message) Iterate over registeredHandlerMethodArgumentResolvers
and invoke the one that supports it.ModifierConstructorDescriptionMethodArgumentResolutionException
(Message<?> message, MethodParameter parameter) Create a new instance providing the invalidMethodParameter
.MethodArgumentResolutionException
(Message<?> message, MethodParameter parameter, String description) Create a new instance providing the invalidMethodParameter
and a prepared description.MethodArgumentResolutionException
(Message<?> message, MethodParameter parameter, String description, Throwable cause) Create a new instance providing the invalidMethodParameter
, prepared description, and a cause. -
Uses of Message in org.springframework.messaging.handler.invocation.reactive
Modifier and TypeMethodDescriptionprotected abstract RouteMatcher.Route
AbstractMethodMessageHandler.getDestination
(Message<?> message) Extract the destination from the given message.protected abstract Comparator<T>
AbstractMethodMessageHandler.getMappingComparator
(Message<?> message) Return a comparator for sorting matching mappings.protected abstract T
AbstractMethodMessageHandler.getMatchingMapping
(T mapping, Message<?> message) Check if a mapping matches the current message and return a possibly new mapping with conditions relevant to the current request.protected abstract reactor.core.publisher.Mono<Void>
AbstractEncoderMethodReturnValueHandler.handleEncodedContent
(reactor.core.publisher.Flux<DataBuffer> encodedContent, MethodParameter returnType, Message<?> message) Subclasses implement this method to handle encoded values in some way such as creating and sending messages.protected reactor.core.publisher.Mono<Void>
AbstractMethodMessageHandler.handleMatch
(T mapping, HandlerMethod handlerMethod, Message<?> message) reactor.core.publisher.Mono<Void>
AbstractMethodMessageHandler.handleMessage
(Message<?> message) protected abstract reactor.core.publisher.Mono<Void>
AbstractEncoderMethodReturnValueHandler.handleNoContent
(MethodParameter returnType, Message<?> message) Invoked for anull
return value, which could mean a void method or method returning an async type parameterized by void.protected void
AbstractMethodMessageHandler.handleNoMatch
(RouteMatcher.Route destination, Message<?> message) Invoked when no matching handler is found.reactor.core.publisher.Mono<Void>
AbstractEncoderMethodReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) reactor.core.publisher.Mono<Void>
HandlerMethodReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) Handle the given return value.reactor.core.publisher.Mono<Void>
HandlerMethodReturnValueHandlerComposite.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) reactor.core.publisher.Mono<Object>
Invoke the method for the given exchange.reactor.core.publisher.Mono<Object>
HandlerMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) Resolves a method parameter into an argument value from a given message.reactor.core.publisher.Mono<Object>
HandlerMethodArgumentResolverComposite.resolveArgument
(MethodParameter parameter, Message<?> message) Iterate over registeredHandlerMethodArgumentResolvers
and invoke the one that supports it.default reactor.core.publisher.Mono<Object>
SyncHandlerMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) Resolves a method parameter into an argument value from a given message.SyncHandlerMethodArgumentResolver.resolveArgumentValue
(MethodParameter parameter, Message<?> message) Resolve the value for the method parameter synchronously. -
Uses of Message in org.springframework.messaging.rsocket.annotation.support
Modifier and TypeMethodDescriptionint
RSocketFrameTypeMessageCondition.compareTo
(RSocketFrameTypeMessageCondition other, Message<?> message) static io.rsocket.frame.FrameType
RSocketFrameTypeMessageCondition.getFrameType
(Message<?> message) Find the RSocket frame type in the message headers.RSocketFrameTypeMessageCondition.getMatchingCondition
(Message<?> message) protected reactor.core.publisher.Mono<Void>
RSocketPayloadReturnValueHandler.handleEncodedContent
(reactor.core.publisher.Flux<DataBuffer> encodedContent, MethodParameter returnType, Message<?> message) protected reactor.core.publisher.Mono<Void>
RSocketPayloadReturnValueHandler.handleNoContent
(MethodParameter returnType, Message<?> message) protected void
RSocketMessageHandler.handleNoMatch
(RouteMatcher.Route destination, Message<?> message) reactor.core.publisher.Mono<Object>
RSocketRequesterMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) -
Uses of Message in org.springframework.messaging.simp
Modifier and TypeMethodDescriptionint
SimpMessageMappingInfo.compareTo
(SimpMessageMappingInfo other, Message<?> message) int
SimpMessageTypeMessageCondition.compareTo
(SimpMessageTypeMessageCondition other, Message<?> message) protected MessageHeaderAccessor
SimpMessageHeaderAccessor.createAccessor
(Message<?> message) protected void
static SimpAttributes
SimpAttributes.fromMessage
(Message<?> message) Extract the SiMP session attributes from the given message and wrap them in aSimpAttributes
instance.SimpMessageMappingInfo.getMatchingCondition
(Message<?> message) SimpMessageTypeMessageCondition.getMatchingCondition
(Message<?> message) void
If the headers of the given message already contain aSimpMessageHeaderAccessor#DESTINATION_HEADER
then the message is sent without further changes.static void
SimpAttributesContextHolder.setAttributesFromMessage
(Message<?> message) Extract the SiMP session attributes from the given message, wrap them in aSimpAttributes
instance and bind it to the current thread.static SimpMessageHeaderAccessor
Create an instance by copying the headers of a Message.ModifierConstructorDescriptionprotected
SimpMessageHeaderAccessor
(Message<?> message) A constructor for accessing and modifying existing message headers. -
Uses of Message in org.springframework.messaging.simp.annotation.support
Modifier and TypeMethodDescriptionprotected String
SimpAnnotationMethodMessageHandler.getDestination
(Message<?> message) protected Comparator<SimpMessageMappingInfo>
SimpAnnotationMethodMessageHandler.getMappingComparator
(Message<?> message) protected SimpMessageMappingInfo
SimpAnnotationMethodMessageHandler.getMatchingMapping
(SimpMessageMappingInfo mapping, Message<?> message) protected String[]
SendToMethodReturnValueHandler.getTargetDestinations
(Annotation annotation, Message<?> message, String defaultPrefix) protected String
SendToMethodReturnValueHandler.getUserName
(Message<?> message, MessageHeaders headers) protected void
SimpAnnotationMethodMessageHandler.handleMatch
(SimpMessageMappingInfo mapping, HandlerMethod handlerMethod, String lookupDestination, Message<?> message) void
SendToMethodReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) void
SubscriptionMethodReturnValueHandler.handleReturnValue
(Object returnValue, MethodParameter returnType, Message<?> message) PrincipalMethodArgumentResolver.resolveArgument
(MethodParameter parameter, Message<?> message) -
Uses of Message in org.springframework.messaging.simp.broker
Modifier and TypeMethodDescriptionprotected abstract void
AbstractSubscriptionRegistry.addSubscriptionInternal
(String sessionId, String subscriptionId, String destination, Message<?> message) protected void
DefaultSubscriptionRegistry.addSubscriptionInternal
(String sessionId, String subscriptionId, String destination, Message<?> message) final MultiValueMap<String,
String> AbstractSubscriptionRegistry.findSubscriptions
(Message<?> message) SubscriptionRegistry.findSubscriptions
(Message<?> message) Find all subscriptions that should receive the given message.protected abstract MultiValueMap<String,
String> AbstractSubscriptionRegistry.findSubscriptionsInternal
(String destination, Message<?> message) protected MultiValueMap<String,
String> DefaultSubscriptionRegistry.findSubscriptionsInternal
(String destination, Message<?> message) static Runnable
OrderedMessageChannelDecorator.getNextMessageTask
(Message<?> message) Obtain the task to release the next message, if found.void
AbstractBrokerMessageHandler.handleMessage
(Message<?> message) protected abstract void
AbstractBrokerMessageHandler.handleMessageInternal
(Message<?> message) protected void
SimpleBrokerMessageHandler.handleMessageInternal
(Message<?> message) final void
AbstractSubscriptionRegistry.registerSubscription
(Message<?> message) void
SubscriptionRegistry.registerSubscription
(Message<?> subscribeMessage) Register a subscription represented by the given message.protected abstract void
AbstractSubscriptionRegistry.removeSubscriptionInternal
(String sessionId, String subscriptionId, Message<?> message) protected void
DefaultSubscriptionRegistry.removeSubscriptionInternal
(String sessionId, String subscriptionId, Message<?> message) boolean
boolean
protected void
SimpleBrokerMessageHandler.sendMessageToSubscribers
(String destination, Message<?> message) final void
AbstractSubscriptionRegistry.unregisterSubscription
(Message<?> message) void
SubscriptionRegistry.unregisterSubscription
(Message<?> unsubscribeMessage) Unregister a subscription. -
Uses of Message in org.springframework.messaging.simp.stomp
Modifier and TypeMethodDescriptionBufferingStompDecoder.decode
(ByteBuffer newBuffer) Decodes one or more STOMP frames from the givenByteBuffer
into a list ofMessages
.StompDecoder.decode
(ByteBuffer byteBuffer) Decodes one or more STOMP frames from the givenByteBuffer
into a list ofMessages
.StompDecoder.decode
(ByteBuffer byteBuffer, MultiValueMap<String, String> partialMessageHeaders) Decodes one or more STOMP frames from the givenbuffer
and returns a list ofMessages
.StompTcpMessageCodec.decode
(ByteBuffer nioBuffer) StompReactorNettyCodec.decodeInternal
(ByteBuffer nioBuffer) Modifier and TypeMethodDescriptionprotected MessageHeaderAccessor
StompHeaderAccessor.createAccessor
(Message<?> message) byte[]
Encodes the given STOMPmessage
into abyte[]
.protected ByteBuffer
StompReactorNettyCodec.encodeInternal
(Message<byte[]> message) void
DefaultStompSession.handleMessage
(Message<byte[]> message) protected void
StompBrokerRelayMessageHandler.handleMessageInternal
(Message<?> message) static StompHeaderAccessor
Create an instance from the payload and headers of the given Message. -
Uses of Message in org.springframework.messaging.simp.user
Modifier and TypeMethodDescriptionvoid
UserDestinationMessageHandler.handleMessage
(Message<?> sourceMessage) void
UserRegistryMessageHandler.handleMessage
(Message<?> message) DefaultUserDestinationResolver.resolveDestination
(Message<?> message) UserDestinationResolver.resolveDestination
(Message<?> message) Resolve the given message with a user destination to one or more messages with actual destinations, one for each active user session. -
Uses of Message in org.springframework.messaging.support
Modifier and TypeClassDescriptionclass
AGenericMessage
with aThrowable
payload.class
An implementation ofMessage
with a generic payload.Modifier and TypeMethodDescriptionMessage<?>
AbstractMessageChannel.ChannelInterceptorChain.applyPostReceive
(Message<?> message, MessageChannel channel) Message<?>
AbstractMessageChannel.ChannelInterceptorChain.applyPreSend
(Message<?> message, MessageChannel channel) default Message<?>
ExecutorChannelInterceptor.beforeHandle
(Message<?> message, MessageChannel channel, MessageHandler handler) Invoked inside theRunnable
submitted to the Executor just before calling the target MessageHandler to handle the message.MessageBuilder.build()
static <T> Message<T>
MessageBuilder.createMessage
(T payload, MessageHeaders messageHeaders) A shortcut factory method for creating a message with the given payload andMessageHeaders
.Message<?>
MessageHandlingRunnable.getMessage()
Return the Message that will be handled.Message<?>
ErrorMessage.getOriginalMessage()
Return the original message (if available) at the point in the stack where the ErrorMessage was created.default Message<?>
ChannelInterceptor.postReceive
(Message<?> message, MessageChannel channel) Invoked immediately after a Message has been retrieved but before it is returned to the caller.default Message<?>
ChannelInterceptor.preSend
(Message<?> message, MessageChannel channel) Invoked before the Message is actually sent to the channel.Message<?>
ImmutableMessageChannelInterceptor.preSend
(Message<?> message, MessageChannel channel) Modifier and TypeMethodDescriptiondefault void
ExecutorChannelInterceptor.afterMessageHandled
(Message<?> message, MessageChannel channel, MessageHandler handler, Exception ex) Invoked inside theRunnable
submitted to the Executor after calling the target MessageHandler regardless of the outcome (i.e.default void
ChannelInterceptor.afterReceiveCompletion
(Message<?> message, MessageChannel channel, Exception ex) Invoked after the completion of a receive regardless of any exception that have been raised thus allowing for proper resource cleanup.default void
ChannelInterceptor.afterSendCompletion
(Message<?> message, MessageChannel channel, boolean sent, Exception ex) Invoked after the completion of a send regardless of any exception that have been raised thus allowing for proper resource cleanup.Message<?>
AbstractMessageChannel.ChannelInterceptorChain.applyPostReceive
(Message<?> message, MessageChannel channel) void
AbstractMessageChannel.ChannelInterceptorChain.applyPostSend
(Message<?> message, MessageChannel channel, boolean sent) Message<?>
AbstractMessageChannel.ChannelInterceptorChain.applyPreSend
(Message<?> message, MessageChannel channel) default Message<?>
ExecutorChannelInterceptor.beforeHandle
(Message<?> message, MessageChannel channel, MessageHandler handler) Invoked inside theRunnable
submitted to the Executor just before calling the target MessageHandler to handle the message.protected MessageHeaderAccessor
MessageHeaderAccessor.createAccessor
(Message<?> message) Build a 'nested' accessor for the given message.static <T> MessageBuilder<T>
MessageBuilder.fromMessage
(Message<T> message) Create a builder for a newMessage
instance pre-populated with all the headers copied from the provided message.static MessageHeaderAccessor
MessageHeaderAccessor.getAccessor
(Message<?> message) Return the originalMessageHeaderAccessor
used to create the headers of the givenMessage
, ornull
if that's not available or if its type does not match the required type.static <T extends MessageHeaderAccessor>
TMessageHeaderAccessor.getAccessor
(Message<?> message, Class<T> requiredType) Return the originalMessageHeaderAccessor
used to create the headers of the givenMessage
, ornull
if that's not available or if its type does not match the required type.static MessageHeaderAccessor
MessageHeaderAccessor.getMutableAccessor
(Message<?> message) Return a mutableMessageHeaderAccessor
for the given message attempting to match the type of accessor used to create the message headers, or otherwise wrapping the message with aMessageHeaderAccessor
instance.default Message<?>
ChannelInterceptor.postReceive
(Message<?> message, MessageChannel channel) Invoked immediately after a Message has been retrieved but before it is returned to the caller.default void
ChannelInterceptor.postSend
(Message<?> message, MessageChannel channel, boolean sent) Invoked immediately after the send invocation.default Message<?>
ChannelInterceptor.preSend
(Message<?> message, MessageChannel channel) Invoked before the Message is actually sent to the channel.Message<?>
ImmutableMessageChannelInterceptor.preSend
(Message<?> message, MessageChannel channel) final boolean
final boolean
protected abstract boolean
AbstractMessageChannel.sendInternal
(Message<?> message, long timeout) boolean
ExecutorSubscribableChannel.sendInternal
(Message<?> message, long timeout) void
AbstractMessageChannel.ChannelInterceptorChain.triggerAfterReceiveCompletion
(Message<?> message, MessageChannel channel, Exception ex) void
AbstractMessageChannel.ChannelInterceptorChain.triggerAfterSendCompletion
(Message<?> message, MessageChannel channel, boolean sent, Exception ex) ModifierConstructorDescriptionCreate a new message with the given payload, headers and original message.ErrorMessage
(Throwable payload, Message<?> originalMessage) Create a new message with the given payload and original message.ErrorMessage
(Throwable payload, MessageHeaders headers, Message<?> originalMessage) Create a new message with the payload,MessageHeaders
and original message.MessageHeaderAccessor
(Message<?> message) A constructor accepting the headers of an existing message to copy.protected
NativeMessageHeaderAccessor
(Message<?> message) Protected constructor that copies headers from another message. -
Uses of Message in org.springframework.messaging.tcp
Modifier and TypeMethodDescriptionvoid
TcpConnectionHandler.handleMessage
(Message<P> message) Handle a message received from the remote host.default ListenableFuture<Void>
Deprecated.Send the given message. -
Uses of Message in org.springframework.messaging.tcp.reactor
Modifier and TypeMethodDescriptionAbstractNioBufferReactorNettyCodec.decode
(io.netty.buffer.ByteBuf inputBuffer) ReactorNettyCodec.decode
(io.netty.buffer.ByteBuf inputBuffer) Decode the inputByteBuf
into one or moreMessages
.TcpMessageCodec.decode
(ByteBuffer buffer) Decode the inputByteBuffer
into one or moreMessages
.AbstractNioBufferReactorNettyCodec.decodeInternal
(ByteBuffer nioBuffer) Modifier and TypeMethodDescriptionvoid
void
Encode the givenMessage
to the outputByteBuf
.Encode the givenMessage
to the outputByteBuffer
.protected abstract ByteBuffer
AbstractNioBufferReactorNettyCodec.encodeInternal
(Message<P> message) -
Uses of Message in org.springframework.web.socket.messaging
Modifier and TypeMethodDescriptionMessage<byte[]>
AbstractSubProtocolEvent.getMessage()
Return the Message associated with the event.Message<byte[]>
StompSubProtocolErrorHandler.handleClientMessageProcessingError
(Message<byte[]> clientMessage, Throwable ex) SubProtocolErrorHandler.handleClientMessageProcessingError
(Message<P> clientMessage, Throwable ex) Handle errors thrown while processing client messages providing an opportunity to prepare the error message or to prevent one from being sent.Message<byte[]>
StompSubProtocolErrorHandler.handleErrorMessageToClient
(Message<byte[]> errorMessage) SubProtocolErrorHandler.handleErrorMessageToClient
(Message<P> errorMessage) Handle errors sent from the server side to clients, for example, errors from the"broke relay"
because connectivity failed or the external broker sent an error message, etc.protected Message<byte[]>
StompSubProtocolErrorHandler.handleInternal
(StompHeaderAccessor errorHeaderAccessor, byte[] errorPayload, Throwable cause, StompHeaderAccessor clientHeaderAccessor) Modifier and TypeMethodDescriptionMessage<byte[]>
StompSubProtocolErrorHandler.handleClientMessageProcessingError
(Message<byte[]> clientMessage, Throwable ex) SubProtocolErrorHandler.handleClientMessageProcessingError
(Message<P> clientMessage, Throwable ex) Handle errors thrown while processing client messages providing an opportunity to prepare the error message or to prevent one from being sent.Message<byte[]>
StompSubProtocolErrorHandler.handleErrorMessageToClient
(Message<byte[]> errorMessage) SubProtocolErrorHandler.handleErrorMessageToClient
(Message<P> errorMessage) Handle errors sent from the server side to clients, for example, errors from the"broke relay"
because connectivity failed or the external broker sent an error message, etc.void
SubProtocolWebSocketHandler.handleMessage
(Message<?> message) Handle an outbound Spring Message to a WebSocket client.void
StompSubProtocolHandler.handleMessageToClient
(WebSocketSession session, Message<?> message) Handle STOMP messages going back out to WebSocket clients.void
SubProtocolHandler.handleMessageToClient
(WebSocketSession session, Message<?> message) Handle the givenMessage
to the client associated with the given WebSocket session.StompSubProtocolHandler.resolveSessionId
(Message<?> message) SubProtocolHandler.resolveSessionId
(Message<?> message) Resolve the session id from the given message or returnnull
.protected StompHeaderAccessor
StompSubProtocolHandler.toMutableAccessor
(StompHeaderAccessor headerAccessor, Message<?> message) ModifierConstructorDescriptionprotected
AbstractSubProtocolEvent
(Object source, Message<byte[]> message) Create a new AbstractSubProtocolEvent.protected
AbstractSubProtocolEvent
(Object source, Message<byte[]> message, Principal user) Create a new AbstractSubProtocolEvent.SessionConnectedEvent
(Object source, Message<byte[]> message) Create a new SessionConnectedEvent.SessionConnectedEvent
(Object source, Message<byte[]> message, Principal user) SessionConnectEvent
(Object source, Message<byte[]> message) Create a new SessionConnectEvent.SessionConnectEvent
(Object source, Message<byte[]> message, Principal user) SessionDisconnectEvent
(Object source, Message<byte[]> message, String sessionId, CloseStatus closeStatus) Create a new SessionDisconnectEvent.SessionDisconnectEvent
(Object source, Message<byte[]> message, String sessionId, CloseStatus closeStatus, Principal user) Create a new SessionDisconnectEvent.SessionSubscribeEvent
(Object source, Message<byte[]> message) SessionSubscribeEvent
(Object source, Message<byte[]> message, Principal user) SessionUnsubscribeEvent
(Object source, Message<byte[]> message) SessionUnsubscribeEvent
(Object source, Message<byte[]> message, Principal user)
TcpConnection.sendAsync(Message)