Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
M
- Mail - Class in org.springframework.integration.mail.dsl
-
The factory for Spring Integration Mail components.
- MailHeaderEnricherParser - Class in org.springframework.integration.mail.config
- MailHeaderEnricherParser() - Constructor for class org.springframework.integration.mail.config.MailHeaderEnricherParser
- MailHeaders - Class in org.springframework.integration.mail
-
Pre-defined header names to be used for setting and/or retrieving Mail Message attributes from/to integration Message Headers.
- MailHeadersBuilder - Class in org.springframework.integration.mail.dsl
-
The Mail specific
MapBuilder
implementation. - MailInboundChannelAdapterParser - Class in org.springframework.integration.mail.config
-
Parser for the <inbound-channel-adapter> element of Spring Integration's 'mail' namespace.
- MailInboundChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.MailInboundChannelAdapterParser
- MailInboundChannelAdapterSpec<S extends MailInboundChannelAdapterSpec<S,
R>, R extends AbstractMailReceiver> - Class in org.springframework.integration.mail.dsl - MailInboundChannelAdapterSpec(R) - Constructor for class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- MailInboundChannelAdapterSpec(R, boolean) - Constructor for class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- MailIntegrationEvent - Class in org.springframework.integration.mail.event
- MailIntegrationEvent(Object) - Constructor for class org.springframework.integration.mail.event.MailIntegrationEvent
- MailIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.mail.event.MailIntegrationEvent
- MailNamespaceHandler - Class in org.springframework.integration.mail.config
-
Namespace handler for the 'mail' namespace.
- MailNamespaceHandler() - Constructor for class org.springframework.integration.mail.config.MailNamespaceHandler
- MailOutboundChannelAdapterParser - Class in org.springframework.integration.mail.config
-
Parser for the <outbound-channel-adapter/> element of the 'mail' namespace.
- MailOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.MailOutboundChannelAdapterParser
- MailReceiver - Interface in org.springframework.integration.mail
-
Strategy interface for receiving mail
Messages
. - MailReceiverFactoryBean - Class in org.springframework.integration.mail.config
- MailReceiverFactoryBean() - Constructor for class org.springframework.integration.mail.config.MailReceiverFactoryBean
- MailReceivingMessageSource - Class in org.springframework.integration.mail
-
MessageSource
implementation that delegates to aMailReceiver
to poll a mailbox. - MailReceivingMessageSource(MailReceiver) - Constructor for class org.springframework.integration.mail.MailReceivingMessageSource
- MailSendingMessageHandler - Class in org.springframework.integration.mail
-
A
MessageHandler
implementation for sending mail. - MailSendingMessageHandler(MailSender) - Constructor for class org.springframework.integration.mail.MailSendingMessageHandler
-
Create a MailSendingMessageHandler.
- MailSendingMessageHandlerSpec - Class in org.springframework.integration.mail.dsl
- MailSendingMessageHandlerSpec(String) - Constructor for class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
- MailToStringTransformer - Class in org.springframework.integration.mail.transformer
-
Transforms a Message payload of type
Message
to a String. - MailToStringTransformer() - Constructor for class org.springframework.integration.mail.transformer.MailToStringTransformer
- MailToStringTransformerParser - Class in org.springframework.integration.mail.config
-
Parser for the <mail-to-string-transformer> element.
- MailToStringTransformerParser() - Constructor for class org.springframework.integration.mail.config.MailToStringTransformerParser
- MailTransportUtils - Class in org.springframework.integration.mail
-
Collection of utility methods to work with Mail transports.
- MailTransportUtils() - Constructor for class org.springframework.integration.mail.MailTransportUtils
- MailUtils - Class in org.springframework.integration.mail.support
-
Utilities for handling mail messages.
- MAJORITY - Enum constant in enum class org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
- MAJORITY_OR_TIE - Enum constant in enum class org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
- makeDirectories(String, Session<F>, String, Log) - Static method in class org.springframework.integration.file.remote.RemoteFileUtils
-
Recursively create remote directories.
- ManageableLifecycle - Interface in org.springframework.integration.support.management
-
Makes
Lifecycle
methods manageable. - ManageableSmartLifecycle - Interface in org.springframework.integration.support.management
-
Extend
ManageableLifecycle
to make those methods manageable. - managedComponents() - Element in annotation interface org.springframework.integration.jmx.config.EnableIntegrationMBeanExport
-
A list of simple patterns for component names to register (defaults to '*').
- MANAGEMENT_CONFIGURER_NAME - Static variable in class org.springframework.integration.config.IntegrationManagementConfigurer
-
Bean name of the configurer.
- managementConfigurer(ObjectProvider<MetricsCaptor>, ObjectProvider<ObservationRegistry>) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
- ManagementOverrides() - Constructor for class org.springframework.integration.support.management.IntegrationManagement.ManagementOverrides
- ManualAckListenerExecutionFailedException - Exception in org.springframework.integration.amqp.support
-
A
ListenerExecutionFailedException
enhanced with the channel and delivery tag. - ManualAckListenerExecutionFailedException(String, Throwable, Channel, long, Message...) - Constructor for exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
-
Construct an instance with the provided properties.
- manualAcks - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- MAP_KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- MapArgumentResolver - Class in org.springframework.integration.handler.support
-
A
HandlerMethodArgumentResolver
implementation to resolve argument for theMethodParameter
as aMap
orProperties
. - MapArgumentResolver() - Constructor for class org.springframework.integration.handler.support.MapArgumentResolver
- MapBuilder<B extends MapBuilder<B,
K, V>, K, V> - Class in org.springframework.integration.support -
A
Builder
pattern implementation for theMap
. - MapBuilder() - Constructor for class org.springframework.integration.support.MapBuilder
- mapCleared(MapEvent) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
- MapContentMatchers<T,
V> - Class in org.springframework.integration.test.matcher -
Matchers that examine the contents of a
Map
. - mapEvicted(MapEvent) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
- mapHeaders(Message<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
- MapJsonSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Serializes a
Map
as JSON. - MapJsonSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
- mapMessage(Message<?>, MessageConverter, AmqpHeaderMapper, boolean, boolean, MessageProperties) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map a reply o.s.m.Message to an o.s.a.core.Message.
- mapMessage(Message<?>, MessageConverter, AmqpHeaderMapper, MessageDeliveryMode, boolean) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map an o.s.m.Message to an o.s.a.core.Message.
- MapMessageConverter - Class in org.springframework.integration.support.converter
-
Converts to/from a Map with 2 keys ('headers' and 'payload').
- MapMessageConverter() - Constructor for class org.springframework.integration.support.converter.MapMessageConverter
- mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Only applies if the default header mapper is used.
- mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Provide the header names that should be mapped to a response from a
MessageHeaders
. - mappedReplyHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Only applies if the default header mapper is used.
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Only applies if the default header mapper is used.
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Provide the header names that should be mapped from a request to a
MessageHeaders
. - mappedRequestHeaders(String...) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Provide the header names that should be mapped from a request to a
MessageHeaders
. - mappedRequestHeaders(String...) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
-
Provide the pattern array for request headers to map.
- mappedRequestHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Provide the pattern array for request headers to map.
- mappedResponseHeaders(String...) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
-
Provide the pattern array for response headers to map.
- mappedResponseHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Provide the pattern array for response headers to map.
- mapper() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
An
MethodArgsMessageMapper
to map the method arguments to aMessage
. - mapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
An
MethodArgsMessageMapper
to map the method arguments to aMessage
. - mapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- MAPPER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- MappingMessageRouterManagement - Interface in org.springframework.integration.support.management
-
Exposes channel mapping operations when the router is proxied.
- MappingUtils - Class in org.springframework.integration.amqp.support
-
Utility methods used during message mapping.
- mapReplyMessage(Message<?>, MessageConverter, AmqpHeaderMapper, MessageDeliveryMode, boolean) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Map a reply o.s.m.Message to an o.s.a.core.Message.
- mapRow(ResultSet, int) - Method in class org.springframework.integration.jdbc.store.channel.MessageRowMapper
- MapToObjectTransformer - Class in org.springframework.integration.transformer
-
Will transform Map to an instance of Object.
- MapToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
- MapToObjectTransformer(String) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
- MapToObjectTransformerParser - Class in org.springframework.integration.config.xml
- MapToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.MapToObjectTransformerParser
- mark() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- MARKER - Static variable in class org.springframework.integration.file.FileHeaders
-
Record is a file marker (START/END).
- markers() - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- markers(boolean) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
-
Specify if
FileSplitter
should emitFileSplitter.FileMarker
s and if they should be converted to the JSON string representation. - marshaller(Marshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
-
Specify a marshaller to use.
- marshaller(Marshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
-
Configure the marshaller to use.
- marshallingInboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance.
- marshallingInboundGateway(Marshaller) - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance with the provided
Marshaller
(which must also implementUnmarshaller
). - marshallingOutboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance with a default
WebServiceTemplate
. - marshallingOutboundGateway(WebServiceTemplate) - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance with the provided
WebServiceTemplate
. - MarshallingTransformer - Class in org.springframework.integration.xml.transformer
-
An implementation of
AbstractTransformer
that delegates to an OXMMarshaller
. - MarshallingTransformer(Marshaller) - Constructor for class org.springframework.integration.xml.transformer.MarshallingTransformer
- MarshallingTransformer(Marshaller, ResultTransformer) - Constructor for class org.springframework.integration.xml.transformer.MarshallingTransformer
- MarshallingTransformerParser - Class in org.springframework.integration.xml.config
- MarshallingTransformerParser() - Constructor for class org.springframework.integration.xml.config.MarshallingTransformerParser
- MarshallingWebServiceInboundGateway - Class in org.springframework.integration.ws
- MarshallingWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
Creates a new
MarshallingWebServiceInboundGateway
. - MarshallingWebServiceInboundGateway(Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
Creates a new
MarshallingWebServiceInboundGateway
with the given marshaller. - MarshallingWebServiceInboundGateway(Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
Creates a new
MarshallingWebServiceInboundGateway
with the given marshaller and unmarshaller. - MarshallingWebServiceOutboundGateway - Class in org.springframework.integration.ws
-
An outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.
- MarshallingWebServiceOutboundGateway(String, Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(String, Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(String, Marshaller, Unmarshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(String, Marshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(String, WebServiceTemplate) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
-
Construct an instance based on the provided Web Service URI and
WebServiceTemplate
. - MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, Unmarshaller) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, Unmarshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(DestinationProvider, Marshaller, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- MarshallingWebServiceOutboundGateway(DestinationProvider, WebServiceTemplate) - Constructor for class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
-
Construct an instance based on the provided
DestinationProvider
andWebServiceTemplate
. - MarshallingWsInboundGatewaySpec - Class in org.springframework.integration.ws.dsl
-
The spec for a
MarshallingWebServiceInboundGateway
. - MarshallingWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
- MarshallingWsOutboundGatewayNoTemplateSpec() - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- MarshallingWsOutboundGatewaySpec - Class in org.springframework.integration.ws.dsl
-
The spec for a
MarshallingWebServiceOutboundGateway
. - MarshallingWsOutboundGatewaySpec(WebServiceTemplate) - Constructor for class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec
- MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec - Class in org.springframework.integration.ws.dsl
-
Spec for a
MarshallingWebServiceOutboundGateway
where an externalWebServiceTemplate
is not provided. - matches(Object) - Method in class org.springframework.integration.test.matcher.MessageMatcher
- matches(Object) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
- matches(Object, Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
- matches(Method) - Method in class org.springframework.integration.util.UniqueMethodFilter
- matchesSafely(Map<? super T, ? super V>) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
- matchesSafely(Message<?>) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
- matchesSafely(Message<T>) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
- matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.CompositeHeaderMatcher
- matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
- matchHeader(String) - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
-
Specify if the given
headerName
matches. - matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
- matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
- matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
- MAX_MESSAGES_UNBOUNDED - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
The constant for unlimited number of message to poll in one cycle.
- maxAge(long) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
-
The maximum age (in seconds) of the cache duration for pre-flight responses.
- maxAttempts(int) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Set the maximum number of release attempts for when message release fails.
- maxConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- maxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
The max for concurrent consumers number to use.
- maxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- maxFetchSize(int) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Specify the maximum number of remote files that will be fetched on each fetch attempt.
- maxFetchSize(int) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Specify the maximum number of remote files that will be fetched on each fetch attempt.
- maxFetchSize(int) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- maxFetchSize(int) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
The maximum for fetch size.
- maxMessagesPerPoll() - Element in annotation interface org.springframework.integration.annotation.Poller
- maxMessagesPerPoll(long) - Method in class org.springframework.integration.dsl.PollerSpec
- maxMessagesPerTask(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
The max messages per task.
- maxMessagesPerTask(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Only applies if the
JmsMessageChannelSpec.containerType(Class)
is aDefaultMessageListenerContainer
. - maxMessagesPerTask(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- maxResults(int) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
-
Set the maximum number of results expression.
- maxResults(int) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
-
Set the maximum number of results expression.
- maxResultsExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
-
Specify a SpEL expression for maximum number of results expression.
- maxResultsExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
-
Specify a SpEL expression for maximum number of results expression.
- maxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
-
Specify a SpEL expression for maximum number of results expression.
- maxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
-
Specify a SpEL expression for maximum number of results expression.
- maxSubscribers - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
- maxSubscribers - Variable in class org.springframework.integration.dsl.LoadBalancingChannelSpec
- maxSubscribers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- maxSubscribers(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.LoadBalancingChannelSpec
- maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
- MBEAN_EXPORTER_NAME - Static variable in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
-
A name for default
IntegrationMBeanExporter
bean. - MBeanAttributeFilter - Interface in org.springframework.integration.jmx
- mbeanExporter() - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
- MBeanExporterParser - Class in org.springframework.integration.jmx.config
-
Parser for the 'mbean-export' element of the integration JMX namespace.
- MBeanExporterParser() - Constructor for class org.springframework.integration.jmx.config.MBeanExporterParser
- MBeanObjectConverter - Interface in org.springframework.integration.jmx
- MBeanTreePollingChannelAdapterParser - Class in org.springframework.integration.jmx.config
- MBeanTreePollingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
- MBeanTreePollingMessageSource - Class in org.springframework.integration.jmx
-
A
MessageSource
implementation that retrieves a snapshot of a filtered subset of the MBean tree. - MBeanTreePollingMessageSource(MBeanObjectConverter) - Constructor for class org.springframework.integration.jmx.MBeanTreePollingMessageSource
- MEMBER - Static variable in class org.springframework.integration.hazelcast.HazelcastHeaders
-
The member header name.
- memberRemoved(MembershipEvent) - Method in class org.springframework.integration.hazelcast.listener.HazelcastMembershipListener
- MEMBERSHIP - Enum constant in enum class org.springframework.integration.hazelcast.ClusterMonitorType
-
The membership listener mode.
- merge(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- merge(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
The entity to be merged with the
EntityManager
. - merge(Object, int, boolean) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- merge(Object, int, boolean) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
The entity to be merged with the
EntityManager
. - MERGE - Enum constant in enum class org.springframework.integration.jpa.support.PersistMode
- mergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
-
Flag which determines if the default converters should be available after custom converters.
- MESSAGE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- MESSAGE - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
- message_channel - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- MESSAGE_EXPIRY_INTERVAL - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- MESSAGE_FORMAT_ERROR - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- MESSAGE_GROUP_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
- MESSAGE_HANDLER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- MESSAGE_ID - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
- MESSAGE_ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- MESSAGE_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
- MESSAGE_PUBLISHING_ERROR_HANDLER_BEAN_NAME - Static variable in class org.springframework.integration.channel.ChannelUtils
- message_routing - Enum constant in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
- MESSAGE_SOURCE - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- MESSAGE_SOURCE - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
- message_transformation - Enum constant in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
- messageArgumentCaptor() - Static method in class org.springframework.integration.test.mock.MockIntegration
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- messageArrived(String, MqttMessage) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- MessageBuilder<T> - Class in org.springframework.integration.support
-
The default message builder; creates immutable
GenericMessage
s. - MessageBuilderFactory - Interface in org.springframework.integration.support
- messageBuilderForReply(Object) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- MessageChannelNode - Class in org.springframework.integration.graph
-
Represents a message channel.
- MessageChannelNode(int, String, MessageChannel) - Constructor for class org.springframework.integration.graph.MessageChannelNode
- MessageChannelReference - Class in org.springframework.integration.dsl.support
-
An "artificial"
MessageChannel
implementation which will be unwrapped to theMessageChannel
bean on the bean registration phase. - MessageChannelReference(String) - Constructor for class org.springframework.integration.dsl.support.MessageChannelReference
- MessageChannels - Class in org.springframework.integration.dsl
- MessageChannelSpec<S extends MessageChannelSpec<S,
C>, C extends AbstractMessageChannel> - Class in org.springframework.integration.dsl - MessageChannelSpec() - Constructor for class org.springframework.integration.dsl.MessageChannelSpec
- messageChannelToFlux(MessageChannel) - Static method in class org.springframework.integration.util.IntegrationReactiveUtils
-
Adapt a provided
MessageChannel
into aFlux
source: - aFluxMessageChannel
is returned as is because it is already aPublisher
; - aSubscribableChannel
is subscribed with aMessageHandler
for theSinks.Many.tryEmitNext(Object)
which is returned from this method; - aPollableChannel
is wrapped into aMessageSource
lambda and reusesIntegrationReactiveUtils.messageSourceToFlux(MessageSource)
. - MessageChannelWrapper(MessageChannel, long) - Constructor for record class org.springframework.integration.channel.DefaultHeaderChannelRegistry.MessageChannelWrapper
-
Creates an instance of a
MessageChannelWrapper
record class. - MessageCodec - Class in org.springframework.integration.codec.kryo
-
PojoCodec
configured to encode/decodeMessage<?>
s. - MessageCodec() - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
-
Construct an instance using the default registration ids for message headers.
- MessageCodec(MessageKryoRegistrar) - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
-
Construct an instance using a custom registrar - usually used if different registration ids are required for message headers.
- MessageCollectionCallback<T> - Interface in org.springframework.integration.mongodb.outbound
-
The callback to be used with the
MongoDbOutboundGateway
as an alternative to other query options on the gateway. - messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Configure the adapter's
MessageConverter
; defaults toSimpleMessageConverter
. - messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Configure the gateway's
MessageConverter
; defaults toSimpleMessageConverter
. - messageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- messageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Set the message converter; must be a
RecordMessageConverter
orBatchMessageConverter
depending on mode. - messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
-
Set the message converter to replace the default.
- messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
-
Set the message converter to use with a record-based consumer.
- messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
-
Set the message converter to use.
- messageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.MessageChannelSpec
- messageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Provide a
MessageConverter
(as an alternative toZeroMqMessageHandlerSpec.messageMapper(org.springframework.integration.mapping.OutboundMessageMapper<byte[]>)
) for converting a request message intobyte[]
for sending into ZeroMq socket. - messageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Provide a
MessageConverter
(as an alternative toZeroMqMessageProducerSpec.messageMapper(org.springframework.integration.mapping.InboundMessageMapper<byte[]>)
) for converting a consumed data into a message to produce. - MessageConverter - Interface in org.springframework.integration.syslog
-
A converter to convert the raw message created by the underlying UDP/TCP endpoint to a specific form of Syslog message.
- messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
-
Set the message body converters to use.
- messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
-
Set a list of
HttpMessageConverter
s to be used by the underlyingRestTemplate
. - MessageConvertingTcpMessageMapper - Class in org.springframework.integration.ip.tcp.connection
- MessageConvertingTcpMessageMapper(MessageConverter) - Constructor for class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
- MessageCountReleaseStrategy - Class in org.springframework.integration.aggregator
- MessageCountReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
-
Convenient constructor is only one message is required (threshold=1).
- MessageCountReleaseStrategy(int) - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
-
Construct an instance based on the provided threshold.
- MessageDecorator - Interface in org.springframework.integration.support
-
The
Message
decoration contract. - MessageDispatcher - Interface in org.springframework.integration.dispatcher
-
Strategy interface for dispatching messages to handlers.
- MessageDispatchingException - Exception in org.springframework.integration
-
Exception that indicates an internal error occurred within a
MessageDispatcher
preventing message delivery. - MessageDispatchingException(String) - Constructor for exception org.springframework.integration.MessageDispatchingException
- MessageDispatchingException(Message<?>) - Constructor for exception org.springframework.integration.MessageDispatchingException
- MessageDispatchingException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageDispatchingException
- MessageDispatchingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageDispatchingException
- MessageDocument - Class in org.springframework.integration.mongodb.store
-
The entity class to wrap
Message
to the MongoDB document. - MessageDocument(Message<?>) - Constructor for class org.springframework.integration.mongodb.store.MessageDocument
- MessageDocumentFields - Class in org.springframework.integration.mongodb.store
- messageDrivenChannelAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
-
The factory to produce a
JmsMessageDrivenChannelAdapterSpec
. - messageDrivenChannelAdapter(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.jms.dsl.Jms
-
The factory to produce a
JmsMessageDrivenChannelAdapterSpec
. - messageDrivenChannelAdapter(JmsListenerContainerSpec<?, ? extends AbstractMessageListenerContainer>) - Static method in class org.springframework.integration.jms.dsl.Jms
-
The factory to produce a
JmsMessageDrivenChannelAdapterSpec
. - messageDrivenChannelAdapter(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.jms.dsl.Jms
-
The factory to produce a
JmsMessageDrivenChannelAdapterSpec
. - messageDrivenChannelAdapter(ConsumerFactory<K, V>, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(ConsumerFactory<K, V>, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
Create an initial
KafkaMessageDrivenChannelAdapterSpec
. - messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
Create an initial
KafkaMessageDrivenChannelAdapterSpec
. - MessageEndpoint - Annotation Interface in org.springframework.integration.annotation
-
Stereotype annotation indicating that a class is capable of serving as a Message Endpoint.
- messageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
-
Specify the
WebServiceMessageFactory
to use. - messageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
Specify the
WebServiceMessageFactory
to use. - MessageFilter - Class in org.springframework.integration.filter
-
Message Handler that delegates to a
MessageSelector
. - MessageFilter(MessageSelector) - Constructor for class org.springframework.integration.filter.MessageFilter
-
Create a MessageFilter that will delegate to the given
MessageSelector
. - messageFunctions - Variable in class org.springframework.integration.test.mock.MockMessageHandler
- MessageGatewayNode - Class in org.springframework.integration.graph
-
Represents an inbound gateway.
- MessageGatewayNode(int, String, MessagingGatewaySupport, String, String) - Constructor for class org.springframework.integration.graph.MessageGatewayNode
- MessageGroup - Interface in org.springframework.integration.store
-
A group of messages that are correlated with each other and should be processed in the same context.
- MessageGroupExpiredEvent - Class in org.springframework.integration.aggregator
-
Event representing the expiration of a message group.
- MessageGroupExpiredEvent(Object, Object, int, Date, Date, boolean) - Constructor for class org.springframework.integration.aggregator.MessageGroupExpiredEvent
- MessageGroupFactory - Interface in org.springframework.integration.store
-
The
MessageGroup
factory strategy. - MessageGroupMetadata - Class in org.springframework.integration.store
-
Value Object holding metadata about a MessageGroup in the MessageGroupStore.
- MessageGroupMetadata() - Constructor for class org.springframework.integration.store.MessageGroupMetadata
- MessageGroupMetadata(MessageGroup) - Constructor for class org.springframework.integration.store.MessageGroupMetadata
- MessageGroupProcessor - Interface in org.springframework.integration.aggregator
-
A processor for correlated groups of messages.
- MessageGroupQueue - Class in org.springframework.integration.store
-
A
BlockingQueue
that is backed by aMessageGroupStore
. - MessageGroupQueue(BasicMessageGroupStore, Object) - Constructor for class org.springframework.integration.store.MessageGroupQueue
- MessageGroupQueue(BasicMessageGroupStore, Object, int) - Constructor for class org.springframework.integration.store.MessageGroupQueue
- MessageGroupQueue(BasicMessageGroupStore, Object, int, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
- MessageGroupQueue(BasicMessageGroupStore, Object, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
- messageGroupSize(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Return the number of messages persisted for the specified channel id (groupId) and the specified region (
JdbcChannelMessageStore.setRegion(String)
). - messageGroupSize(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- messageGroupSize(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- messageGroupSize(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- messageGroupSize(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
- messageGroupSize(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
- messageGroupSize(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- messageGroupSize(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
-
Return the size of this MessageGroup.
- messageGroupSize(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
- MessageGroupStore - Interface in org.springframework.integration.store
-
Defines additional storage operations on groups of messages linked by a group id.
- MessageGroupStore.MessageGroupCallback - Interface in org.springframework.integration.store
-
Invoked when a MessageGroupStore expires a group.
- MessageGroupStoreReaper - Class in org.springframework.integration.store
-
Convenient configurable component to allow explicit timed expiry of
MessageGroup
instances in aMessageGroupStore
. - MessageGroupStoreReaper() - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
- MessageGroupStoreReaper(MessageGroupStore) - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
- messageHandlerAttributes - Variable in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- MessageHandlerChain - Class in org.springframework.integration.handler
-
A composite
MessageHandler
implementation that invokes a chain of MessageHandler instances in order. - MessageHandlerChain() - Constructor for class org.springframework.integration.handler.MessageHandlerChain
- MessageHandlerNode - Class in org.springframework.integration.graph
-
Represents a message handler.
- MessageHandlerNode(int, String, MessageHandler, String, String) - Constructor for class org.springframework.integration.graph.MessageHandlerNode
- MessageHandlerSpec<S extends MessageHandlerSpec<S,
H>, H extends MessageHandler> - Class in org.springframework.integration.dsl -
An
IntegrationComponentSpec
forMessageHandler
s. - MessageHandlerSpec() - Constructor for class org.springframework.integration.dsl.MessageHandlerSpec
- MessageHandlerSupport - Class in org.springframework.integration.handler
-
Base class for Message handling components that provides basic validation and error handling capabilities.
- MessageHandlerSupport() - Constructor for class org.springframework.integration.handler.MessageHandlerSupport
- MessageHandlingExpressionEvaluatingAdviceException(Message<?>, String, Throwable, Object) - Constructor for exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
- MessageHandlingTask(MessageHandlingRunnable) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
- MessageHandlingTaskDecorator - Interface in org.springframework.integration.dispatcher
-
The strategy to decorate
MessageHandlingRunnable
tasks to be used with theExecutor
. - messageHeaders(Map<String, Expression>) - Method in class org.springframework.integration.dsl.MessageSourceSpec
-
Expressions with which to enhance headers.
- MessageHeadersJacksonSerializer - Class in org.springframework.integration.support.json
- MessageHeadersJacksonSerializer() - Constructor for class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
- MessageHistory - Class in org.springframework.integration.history
- MessageHistory.Entry - Class in org.springframework.integration.history
-
Inner class for each Entry in the history.
- MessageHistoryConfigurer - Class in org.springframework.integration.history
- MessageHistoryConfigurer() - Constructor for class org.springframework.integration.history.MessageHistoryConfigurer
- MessageHistoryParser - Class in org.springframework.integration.config.xml
-
The
<message-history/>
parser. - MessageHistoryParser() - Constructor for class org.springframework.integration.config.xml.MessageHistoryParser
- MessageHistoryRegistrar - Class in org.springframework.integration.config
- MessageHistoryRegistrar() - Constructor for class org.springframework.integration.config.MessageHistoryRegistrar
- MessageHolder - Class in org.springframework.integration.store
-
The
MessageStore
specific value object to keep theMessage
and its metadata. - MessageHolder(Message<?>) - Constructor for class org.springframework.integration.store.MessageHolder
- messageIdEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- messageIdIterator() - Method in class org.springframework.integration.store.MessageGroupMetadata
- MessageJacksonDeserializer<T extends Message<?>> - Class in org.springframework.integration.support.json
-
A Jackson
StdNodeBasedDeserializer
extension forMessage
implementations. - MessageJacksonDeserializer(Class<T>) - Constructor for class org.springframework.integration.support.json.MessageJacksonDeserializer
- messageKey(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure the message key to store message in Kafka topic.
- messageKey(Function<Message<P>, ?>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a
Function
that will be invoked at runtime to determine the message key under which a message will be stored in the topic. - messageKeyExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a SpEL expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
- messageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure an
Expression
to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context. - MessageKryoRegistrar - Class in org.springframework.integration.codec.kryo
-
Registers common MessageHeader types and Serializers.
- MessageKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.MessageKryoRegistrar
- MessageListenerContainerSpec<S extends MessageListenerContainerSpec<S,
C>, C extends MessageListenerContainer> - Class in org.springframework.integration.amqp.dsl -
Base class for container specs.
- MessageListenerContainerSpec() - Constructor for class org.springframework.integration.amqp.dsl.MessageListenerContainerSpec
- MessageListProcessor - Interface in org.springframework.integration.aggregator
- messageMapper(BytesMessageMapper) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
Provide a
BytesMessageMapper
to convert to/from messages when send or receive happens on the sockets. - messageMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Provide an
InboundMessageMapper
to convert a consumed data into a message to produce. - messageMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Provide an
OutboundMessageMapper
to convert a request message intobyte[]
for sending into ZeroMq socket. - messageMappingCompatible - Variable in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
- MessageMappingException - Exception in org.springframework.integration.mapping
-
Exception that indicates an error during message mapping.
- MessageMappingException(String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
- MessageMappingException(String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
- MessageMappingException(Message<?>, String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
- MessageMappingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
- MessageMatcher - Class in org.springframework.integration.test.matcher
-
Matcher to make assertions about message equality easier.
- MessageMatcher(Message<?>) - Constructor for class org.springframework.integration.test.matcher.MessageMatcher
- MessageMetadata - Class in org.springframework.integration.store
-
Value Object holding metadata about a Message in the MessageStore.
- MessageMetadata(UUID) - Constructor for class org.springframework.integration.store.MessageMetadata
- MessagePredicate - Class in org.springframework.integration.test.predicate
-
Predicate to make assertions about message equality easier.
- MessagePredicate(Message<?>, String...) - Constructor for class org.springframework.integration.test.predicate.MessagePredicate
- MessagePreparedStatementSetter - Interface in org.springframework.integration.jdbc
-
The callback to be used with the
JdbcMessageHandler
as an alternative to theSqlParameterSourceFactory
. - MessageProcessingHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
- MessageProcessingHeaderValueMessageProcessor(Object) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
- MessageProcessingHeaderValueMessageProcessor(Object, String) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
- MessageProcessingHeaderValueMessageProcessor(MessageProcessor<T>) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
- messageProcessor(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
Configure an
ExpressionEvaluatingMessageProcessor
that evaluates to aMap
of additional headers. - messageProcessor(String, String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
Configure an
MethodInvokingMessageProcessor
that invokes the method on the bean - the method must return aMap
of headers. - messageProcessor(MessageProcessor<?>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
Configure an optional custom
MessageProcessor
for the enricher. - MessageProcessor<T> - Interface in org.springframework.integration.handler
-
This defines the lowest-level strategy of processing a Message and returning some Object (or null).
- MessageProcessorMessageSource - Class in org.springframework.integration.endpoint
-
The
MessageSource
strategy implementation to produce aMessage
from underlying MessageProcessorMessageSource.messageProcessor for polling endpoints. - MessageProcessorMessageSource(MessageProcessor<?>) - Constructor for class org.springframework.integration.endpoint.MessageProcessorMessageSource
- MessageProcessorSpec<S extends MessageProcessorSpec<S>> - Class in org.springframework.integration.dsl
-
The
IntegrationComponentSpec
specific base class forMessageProcessor
s. - MessageProcessorSpec() - Constructor for class org.springframework.integration.dsl.MessageProcessorSpec
- MessageProducer - Interface in org.springframework.integration.core
-
Base interface for any component that is capable of sending messages to a
MessageChannel
. - MessageProducerNode - Class in org.springframework.integration.graph
-
Represents an inbound message producer.
- MessageProducerNode(int, String, MessageProducerSupport, String, String) - Constructor for class org.springframework.integration.graph.MessageProducerNode
- MessageProducerSpec<S extends MessageProducerSpec<S,
P>, P extends MessageProducerSupport> - Class in org.springframework.integration.dsl -
An
IntegrationComponentSpec
forMessageProducer
s. - MessageProducerSpec(P) - Constructor for class org.springframework.integration.dsl.MessageProducerSpec
- MessageProducerSupport - Class in org.springframework.integration.endpoint
-
A support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.
- MessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.MessageProducerSupport
- messagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the
MessagePropertiesConverter
for this listener container. - messagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure
messagePropertiesConverter
on both theRabbitTemplate
(for sends) andSimpleMessageListenerContainer
(for receives). - MessagePublishingErrorHandler - Class in org.springframework.integration.channel
- MessagePublishingErrorHandler() - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
- MessagePublishingErrorHandler(DestinationResolver<MessageChannel>) - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
- MessagePublishingInterceptor - Class in org.springframework.integration.aop
-
A
MethodInterceptor
that publishes Messages to a channel. - MessagePublishingInterceptor(PublisherMetadataSource) - Constructor for class org.springframework.integration.aop.MessagePublishingInterceptor
- MessageReceiverContext - Class in org.springframework.integration.support.management.observation
-
The
ReceiverContext
extension forMessage
context. - MessageReceiverContext(Message<?>, String) - Constructor for class org.springframework.integration.support.management.observation.MessageReceiverContext
- MessageReceiverObservationConvention - Interface in org.springframework.integration.support.management.observation
-
A
MessageReceiverContext
-basedObservationConvention
contract. - messageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a
MessageRecoverer
when using retry within the adapter. - messageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a
MessageRecoverer
when using retry within the adapter. - MessageRejectedException - Exception in org.springframework.integration
-
Exception that indicates a message has been rejected by a selector.
- MessageRejectedException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageRejectedException
- MessageRejectedException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageRejectedException
- MessageRequestReplyReceiverContext - Class in org.springframework.integration.support.management.observation
-
The
RequestReplyReceiverContext
extension for aMessage
contract with inbound gateways. - MessageRequestReplyReceiverContext(Message<?>, String) - Constructor for class org.springframework.integration.support.management.observation.MessageRequestReplyReceiverContext
- MessageRequestReplyReceiverObservationConvention - Interface in org.springframework.integration.support.management.observation
-
A
MessageRequestReplyReceiverContext
-basedObservationConvention
contract. - MessageRouter - Interface in org.springframework.integration.router
-
Routers implementing this interface have a default output channel.
- MessageRowMapper - Class in org.springframework.integration.jdbc.store.channel
-
Convenience class to be used to unpack a
Message
from a result set row. - MessageRowMapper(AllowListDeserializingConverter, LobHandler) - Constructor for class org.springframework.integration.jdbc.store.channel.MessageRowMapper
-
Construct an instance based on the provided
AllowListDeserializingConverter
andLobHandler
. - MESSAGES - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
-
Payload is a
List<Message<?>>
where each element is a message is converted from the Spring AMQP Message. - MessageSelectingInterceptor - Class in org.springframework.integration.channel.interceptor
-
A
ChannelInterceptor
that delegates to a list ofMessageSelectors
to decide whether aMessage
should be accepted on theMessageChannel
. - MessageSelectingInterceptor(MessageSelector...) - Constructor for class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
- messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
- messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
- messageSelector(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
Configure a message selector in the
DefaultMessageListenerContainer
(when message driven) or theJmsTemplate
(when polled). - MessageSelector - Interface in org.springframework.integration.core
-
Strategy interface for message selection.
- MessageSelectorChain - Class in org.springframework.integration.selector
-
A message selector implementation that passes incoming messages through a chain of selectors.
- MessageSelectorChain() - Constructor for class org.springframework.integration.selector.MessageSelectorChain
- MessageSelectorChain.VotingStrategy - Enum Class in org.springframework.integration.selector
- MessageSenderContext - Class in org.springframework.integration.support.management.observation
-
The
SenderContext
extension forMessage
context. - MessageSenderContext(MutableMessage<?>, String) - Constructor for class org.springframework.integration.support.management.observation.MessageSenderContext
- MessageSenderObservationConvention - Interface in org.springframework.integration.support.management.observation
-
A
MessageSenderContext
-basedObservationConvention
contract. - messageSenders - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- messageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
-
Specify the
WebServiceMessageSender
s to use. - messageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
Specify the
WebServiceMessageSender
s to use. - MessageSequenceComparator - Class in org.springframework.integration.aggregator
- MessageSequenceComparator() - Constructor for class org.springframework.integration.aggregator.MessageSequenceComparator
- MessageSessionCallback<F,
T> - Interface in org.springframework.integration.file.remote -
Callback invoked by
RemoteFileOperations.executeForMessage()
- allows multiple operations on a session. - messageSource(String) - Static method in class org.springframework.integration.scripting.dsl.Scripts
-
Factory for the
ScriptMessageSourceSpec
based on the script location. - messageSource(Resource) - Static method in class org.springframework.integration.scripting.dsl.Scripts
-
Factory for the
ScriptMessageSourceSpec
based on theResource
. - MessageSource<T> - Interface in org.springframework.integration.core
-
Base interface for any source of
Messages
that can be polled. - MessageSourceManagement - Interface in org.springframework.integration.support.management
-
Message sources implementing this interface have additional properties that can be set or examined using JMX.
- MessageSourceMutator - Interface in org.springframework.integration.aop
-
A
ReceiveMessageAdvice
extension that can mutate aMessageSource
before and/or afterMessageSource.receive()
is called. - MessageSourceNode - Class in org.springframework.integration.graph
-
Represents a message source.
- MessageSourceNode(int, String, MessageSource<?>, String, String) - Constructor for class org.springframework.integration.graph.MessageSourceNode
- MessageSourcePollingTemplate - Class in org.springframework.integration.endpoint
-
A
PollingOperations
used to ad-hoc poll aMessageSource
. - MessageSourcePollingTemplate(MessageSource<?>) - Constructor for class org.springframework.integration.endpoint.MessageSourcePollingTemplate
- MessageSourceSpec<S extends MessageSourceSpec<S,
H>, H extends MessageSource<?>> - Class in org.springframework.integration.dsl -
An
IntegrationComponentSpec
forMessageSource
s. - MessageSourceSpec() - Constructor for class org.springframework.integration.dsl.MessageSourceSpec
- messageSourceToFlux(MessageSource<T>) - Static method in class org.springframework.integration.util.IntegrationReactiveUtils
-
Wrap a provided
MessageSource
into aFlux
for pulling the on demand. - messagesPerAck(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- messageStore(PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
- MessageStore - Interface in org.springframework.integration.store
-
Strategy interface for storing and retrieving messages.
- MessageStoreException - Exception in org.springframework.integration.store
-
Exception for problems that occur when using a
MessageStore
implementation. - MessageStoreException(String) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreException(String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreException(Message<?>) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreException(Message<?>, String) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
- MessageStoreSpec(ChannelMessageStore, Object) - Constructor for class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
- MessageTimeoutException - Exception in org.springframework.integration
-
Exception that indicates a timeout elapsed prior to successful message delivery.
- MessageTimeoutException(String) - Constructor for exception org.springframework.integration.MessageTimeoutException
- MessageTimeoutException(Message<?>) - Constructor for exception org.springframework.integration.MessageTimeoutException
- MessageTimeoutException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageTimeoutException
- MessageTimeoutException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageTimeoutException
- messageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- MessageToBinaryConverter - Class in org.springframework.integration.mongodb.support
- MessageToBinaryConverter() - Constructor for class org.springframework.integration.mongodb.support.MessageToBinaryConverter
- messageToMqttBytes(Message<?>) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Subclasses can override this method to convert the payload to a byte[].
- MessageTransformationException - Exception in org.springframework.integration.transformer
-
Base Exception type for Message transformation errors.
- MessageTransformationException(String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
- MessageTransformationException(String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
- MessageTransformationException(Message<?>, String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
- MessageTransformationException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
- MessageTransformingHandler - Class in org.springframework.integration.transformer
-
A reply-producing
MessageHandler
that delegates to aTransformer
instance to modify the receivedMessage
and sends the result to its output channel. - MessageTransformingHandler(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingHandler
-
Create a
MessageTransformingHandler
instance that delegates to the providedTransformer
. - MessageTriggerAction - Interface in org.springframework.integration.handler
-
Classes implementing this interface can take some action when a trigger
Message
is received. - MessageValidator - Class in org.springframework.integration.test.support
-
Validate a message.
- MessageValidator() - Constructor for class org.springframework.integration.test.support.MessageValidator
- messageWithHeaderEntries(Map<String, ?>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- messageWithHeaderEntry(String, Object) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- messageWithHeaderEntry(String, Matcher<T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- messageWithHeaderKey(String) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- messageWithPayload(Matcher<? super T>) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- messageWithPayload(T) - Static method in class org.springframework.integration.test.matcher.MockitoMessageMatchers
- MESSAGING_ANNOTATION_POSTPROCESSOR_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- messaging_channel - Enum constant in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
- messaging_endpoint - Enum constant in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
- MessagingAnnotationPostProcessor - Class in org.springframework.integration.config
-
A
BeanPostProcessor
implementation that processes method-level messaging annotations such as @Transformer, @Splitter, @Router, and @Filter. - MessagingAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.MessagingAnnotationPostProcessor
- MessagingAnnotationPostProcessor.MessagingMetaAnnotation - Record Class in org.springframework.integration.config
- MessagingAnnotationUtils - Class in org.springframework.integration.util
-
Utility methods to support annotation processing.
- messagingAwareMapper(String...) - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
-
Return an
ObjectMapper
if available, supplied with Message specific serializers and deserializers. - MessagingEvent - Class in org.springframework.integration.event.core
-
A subclass of
ApplicationEvent
that wraps aMessage
. - MessagingEvent(Message<?>) - Constructor for class org.springframework.integration.event.core.MessagingEvent
-
Construct an instance based on the provided message.
- MessagingExceptionWrapper - Exception in org.springframework.integration.support
-
A wrapper exception for a
MessagingException
used to convey the cause and original message to aMessagePublishingErrorHandler
. - MessagingExceptionWrapper(Message<?>, MessagingException) - Constructor for exception org.springframework.integration.support.MessagingExceptionWrapper
- MessagingGateway - Annotation Interface in org.springframework.integration.annotation
-
A stereotype annotation to provide an Integration Messaging Gateway Proxy as an abstraction over the messaging API.
- MessagingGatewaySpec<S extends MessagingGatewaySpec<S,
G>, G extends MessagingGatewaySupport> - Class in org.springframework.integration.dsl - MessagingGatewaySpec(G) - Constructor for class org.springframework.integration.dsl.MessagingGatewaySpec
- MessagingGatewaySupport - Class in org.springframework.integration.gateway
-
A convenient base class for connecting application code to
MessageChannel
s for sending, receiving, or request-reply operations. - MessagingGatewaySupport() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
-
Construct an instance that will return null if no reply is received.
- MessagingGatewaySupport(boolean) - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
-
If errorOnTimeout is true, construct an instance that will send an
ErrorMessage
with aMessageTimeoutException
payload to the error channel if a reply is expected but none is received. - MessagingGatewaySupport.ConvertingMessagingTemplate - Class in org.springframework.integration.gateway
-
The
MessagingTemplate
extension to increaseMessagingGatewaySupport.ConvertingMessagingTemplate.doConvert(Object, Map, MessagePostProcessor)
visibility to get access to the request message from an observation context. - MessagingMetaAnnotation(Annotation, Class<? extends Annotation>) - Constructor for record class org.springframework.integration.config.MessagingAnnotationPostProcessor.MessagingMetaAnnotation
-
Creates an instance of a
MessagingMetaAnnotation
record class. - MessagingMethodInvokerHelper - Class in org.springframework.integration.handler.support
-
A helper class for processors that invoke a method on a target Object using a combination of message payload(s) and headers as arguments.
- MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper(Object, Method, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper(Object, Method, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper(Object, String, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper(Object, String, Class<?>, boolean) - Constructor for class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- MessagingMethodInvokerHelper.ParametersWrapper - Class in org.springframework.integration.handler.support
- messagingTemplate - Variable in class org.springframework.integration.core.ErrorMessagePublisher
- messagingTemplate - Variable in class org.springframework.integration.gateway.MessagingGatewaySupport
- messagingTemplate - Variable in class org.springframework.integration.handler.AbstractMessageProducingHandler
- MessagingTemplate - Class in org.springframework.integration.core
- MessagingTemplate() - Constructor for class org.springframework.integration.core.MessagingTemplate
-
Create a MessagingTemplate with no default channel.
- MessagingTemplate(MessageChannel) - Constructor for class org.springframework.integration.core.MessagingTemplate
-
Create a MessagingTemplate with the given default channel.
- messagingTemplateFor(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
-
Obtain a
MessagingTemplate
with its default destination set to the input channel of theIntegrationFlow
for providedflowId
. - messagingTemplateFor(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
-
Obtain a
MessagingTemplate
with its default destination set to the input channel of theIntegrationFlow
for providedflowId
. - metadata(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
Configure a SpEL expression to evaluate a metadata as a
Map<Object, MimeType>
for the RSocket request against request message. - metadata(Function<Message<P>, Map<Object, MimeType>>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
Configure a
Function
to evaluate a metadata as aMap<Object, MimeType>
for RSocket request against request message. - metadata(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
Configure a SpEL expression to evaluate a metadata as a
Map<Object, MimeType>
for the RSocket request type at runtime against a request message. - METADATA_STORE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- metadataStore(MetadataStore) - Method in class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
- MetadataStore - Interface in org.springframework.integration.metadata
-
Strategy interface for storing metadata from certain adapters to avoid duplicate delivery of messages, for example.
- MetadataStoreListener - Interface in org.springframework.integration.metadata
-
A callback to be invoked whenever a value changes in the data store.
- MetadataStoreListenerAdapter - Class in org.springframework.integration.metadata
-
Base implementation for a
MetadataStoreListener
. - MetadataStoreListenerAdapter() - Constructor for class org.springframework.integration.metadata.MetadataStoreListenerAdapter
- metadataStorePrefix(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Configure a prefix for remote files metadata keys.
- MetadataStoreSelector - Class in org.springframework.integration.selector
- MetadataStoreSelector(MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
- MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
- MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
- MetadataStoreSelector(MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
- METER_PREFIX - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
- METER_REGISTRY_PRESENT - Static variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorConfiguration
-
A
boolean
flag to indicate if theio.micrometer.core.instrument.MeterRegistry
class is present in the CLASSPATH to allow aMicrometerMetricsCaptor
bean. - MeterFacade - Interface in org.springframework.integration.support.management.metrics
-
Facade for Meters.
- meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
- meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
- meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
- meterRegistry - Variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
- meters - Variable in class org.springframework.integration.channel.AbstractMessageChannel
- method(RequestMethod...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
-
List of supported HTTP request methods, e.g.
- METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
- METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- METHOD_NAME_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- MethodAnnotationPostProcessor<T extends Annotation> - Interface in org.springframework.integration.config.annotation
-
Strategy interface for post-processing annotated methods.
- MethodAnnotationPublisherMetadataSource - Class in org.springframework.integration.aop
-
An
PublisherMetadataSource
implementation that retrieves the channel name and expression strings from an annotation. - MethodAnnotationPublisherMetadataSource() - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- MethodAnnotationPublisherMetadataSource(Set<Class<? extends Annotation>>) - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- MethodArgsHolder - Class in org.springframework.integration.gateway
-
Simple wrapper class containing a
Method
and an object array containing the arguments for an invocation of that method. - MethodArgsHolder(Method, Object[]) - Constructor for class org.springframework.integration.gateway.MethodArgsHolder
- MethodArgsMessageMapper - Interface in org.springframework.integration.gateway
-
Implementations of this interface are
InboundMessageMapper
s that map aMethodArgsHolder
to aMessage
. - MethodInvokingCorrelationStrategy - Class in org.springframework.integration.aggregator
-
CorrelationStrategy
implementation that works as an adapter to another bean. - MethodInvokingCorrelationStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
- MethodInvokingCorrelationStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
- MethodInvokingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
MessageGroupProcessor that serves as an adapter for the invocation of a POJO method.
- MethodInvokingMessageGroupProcessor(Object) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
Creates a wrapper around the object passed in.
- MethodInvokingMessageGroupProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
Creates a wrapper around the object passed in.
- MethodInvokingMessageGroupProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
Creates a wrapper around the object passed in.
- MethodInvokingMessageHandler - Class in org.springframework.integration.handler
-
A
MessageHandler
that invokes the specified method on the provided object. - MethodInvokingMessageHandler(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
- MethodInvokingMessageHandler(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
- MethodInvokingMessageListProcessor<T> - Class in org.springframework.integration.aggregator
-
A MessageListProcessor implementation that invokes a method on a target POJO.
- MethodInvokingMessageListProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- MethodInvokingMessageListProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- MethodInvokingMessageListProcessor(Object, Method, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- MethodInvokingMessageListProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- MethodInvokingMessageListProcessor(Object, String, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- MethodInvokingMessageProcessor<T> - Class in org.springframework.integration.handler
-
A MessageProcessor implementation that invokes a method on a target Object.
- MethodInvokingMessageProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
- MethodInvokingMessageProcessor(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
- MethodInvokingMessageProcessor(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
- MethodInvokingMessageProcessor(Object, String, boolean) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
- MethodInvokingMessageSource - Class in org.springframework.integration.endpoint
-
A
MessageSource
implementation that invokes a no-argument method so that its return value may be sent to a channel. - MethodInvokingMessageSource() - Constructor for class org.springframework.integration.endpoint.MethodInvokingMessageSource
- MethodInvokingReleaseStrategy - Class in org.springframework.integration.aggregator
-
A
ReleaseStrategy
that invokes a method on a plain old Java object. - MethodInvokingReleaseStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
- MethodInvokingReleaseStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
- MethodInvokingRouter - Class in org.springframework.integration.router
-
A Message Router that invokes the specified method on the given object.
- MethodInvokingRouter(Object) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
- MethodInvokingRouter(Object, Method) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
- MethodInvokingRouter(Object, String) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
- MethodInvokingSelector - Class in org.springframework.integration.filter
-
A method-invoking implementation of
MessageSelector
. - MethodInvokingSelector(Object) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
- MethodInvokingSelector(Object, Method) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
- MethodInvokingSelector(Object, String) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
- MethodInvokingSplitter - Class in org.springframework.integration.splitter
-
A Message Splitter implementation that invokes the specified method on the given object.
- MethodInvokingSplitter(Object) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
- MethodInvokingSplitter(Object, Method) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
- MethodInvokingSplitter(Object, String) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
- MethodInvokingTransformer - Class in org.springframework.integration.transformer
-
A Message Transformer implementation that invokes the specified method on the given object.
- MethodInvokingTransformer(Object) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
- MethodInvokingTransformer(Object, Method) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
- MethodInvokingTransformer(Object, String) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
- methodIsHandleMessageOrEmpty(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- MethodNameMappingPublisherMetadataSource - Class in org.springframework.integration.aop
- MethodNameMappingPublisherMetadataSource(Map<String, String>) - Constructor for class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
- methods(HttpMethod...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
-
The HTTP request methods to map to, narrowing the primary mapping: GET, POST, HEAD, OPTIONS, PUT, PATCH, DELETE, TRACE.
- MetricsCaptor - Interface in org.springframework.integration.support.management.metrics
-
A metrics facade that delegates to a concrete implementation.
- MetricsCaptor.CounterBuilder - Interface in org.springframework.integration.support.management.metrics
-
A builder for a counter.
- MetricsCaptor.GaugeBuilder - Interface in org.springframework.integration.support.management.metrics
-
A builder for a gauge.
- MetricsCaptor.TimerBuilder - Interface in org.springframework.integration.support.management.metrics
-
A builder for a timer.
- mGet(Message<?>, Session<F>, String, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- mGet(Message<?>, Session<FTPFile>, String, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- MGET - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
-
(mget) Retrieve multiple files matching a wildcard path.
- MicroCounter(Counter, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
- MicroCounterBuilder(MeterRegistry, String) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
- MicroGauge(Gauge, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
- MicroGaugeBuilder(MeterRegistry, String, Object, ToDoubleFunction<Object>) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
- MICROMETER_CAPTOR_NAME - Static variable in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
- micrometerMetricsCaptor(ObjectProvider<MeterRegistry>) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorConfiguration
- MicrometerMetricsCaptor - Class in org.springframework.integration.support.management.micrometer
-
The Micrometer implementation of
MetricsCaptor
. - MicrometerMetricsCaptor(MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
- MicrometerMetricsCaptor.AbstractMeter<M extends io.micrometer.core.instrument.Meter> - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroCounter - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroCounterBuilder - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroGauge - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroGaugeBuilder - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroTimer - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptor.MicroTimerBuilder - Class in org.springframework.integration.support.management.micrometer
- MicrometerMetricsCaptorConfiguration - Class in org.springframework.integration.support.management.micrometer
-
A
Configuration
to add aMicrometerMetricsCaptor
. - MicrometerMetricsCaptorConfiguration() - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorConfiguration
- MicrometerMetricsCaptorImportSelector - Class in org.springframework.integration.support.management.micrometer
-
An
ImportSelector
to conditionally add aMicrometerMetricsCaptorConfiguration
bean whenio.micrometer.core.instrument.MeterRegistry
is present in classpath. - MicrometerMetricsCaptorImportSelector() - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorImportSelector
- MicrometerNodeEnhancer - Class in org.springframework.integration.graph
-
Add micrometer metrics to the node.
- MicroTimer(Timer, MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
- MIGRATION - Enum constant in enum class org.springframework.integration.hazelcast.ClusterMonitorType
-
The migration listener mode.
- MimeTypeSerializer - Class in org.springframework.integration.support.json
-
Simple
StdSerializer
extension to represent aMimeType
object in the target JSON as a plain string. - MimeTypeSerializer() - Constructor for class org.springframework.integration.support.json.MimeTypeSerializer
- MIN_REGISTRATION_VALUE - Static variable in interface org.springframework.integration.codec.kryo.KryoRegistrar
- minimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- minSubscribers(int) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
- mismatchedQueuesFatal(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Prevent the container from starting if any of the queues defined in the context have mismatched arguments (TTL etc.).
- missingQueuesFatal(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
If all the configured queue(s) are not available on the broker, this setting determines whether the condition is fatal.
- mkdir(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- mkdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
- mkdir(String) - Method in class org.springframework.integration.ftp.session.FtpSession
- mkdir(String) - Method in class org.springframework.integration.sftp.session.SftpSession
- mkdir(String) - Method in class org.springframework.integration.smb.session.SmbSession
-
Create the specified remote path if not yet exists.
- MOCK_INTEGRATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.test.context.MockIntegrationContext
-
The bean name for the mock integration context.
- MockIntegration - Class in org.springframework.integration.test.mock
-
The factory for integration specific mock components.
- MockIntegrationContext - Class in org.springframework.integration.test.context
-
A
BeanFactoryAware
component with an API to customize real beans in the application context from test code. - MockIntegrationContext() - Constructor for class org.springframework.integration.test.context.MockIntegrationContext
- MockitoMessageMatchers - Class in org.springframework.integration.test.matcher
-
Mockito matcher factory for
Message
matcher creation. - mockMessageHandler() - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a
MockMessageHandler
instance. - mockMessageHandler(ArgumentCaptor<Message<?>>) - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a
MockMessageHandler
instance based on the providedArgumentCaptor
. - MockMessageHandler - Class in org.springframework.integration.test.mock
-
The
AbstractMessageProducingHandler
extension for the mocking purpose in tests. - MockMessageHandler(ArgumentCaptor<Message<?>>) - Constructor for class org.springframework.integration.test.mock.MockMessageHandler
- mockMessageSource(Message<?>) - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a mock for the
MessageSource
based on the provided message. - mockMessageSource(Message<?>, Message<?>...) - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a mock for the
MessageSource
based on the provided messages. - mockMessageSource(T) - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a mock for the
MessageSource
based on the provided payload. - mockMessageSource(T, T...) - Static method in class org.springframework.integration.test.mock.MockIntegration
-
Build a mock for the
MessageSource
based on the provided payloads. - modified(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- modified(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
- modified(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbPersistentAcceptOnceFileListFilter
- modified(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
- modified(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
- MODIFY - Enum constant in enum class org.springframework.integration.file.FileReadingMessageSource.WatchEventType
- mongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
-
Configure a custom
MongoConverter
used to assist in deserialization data read from MongoDb. - mongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
Configure a
MongoConverter
. - MongoDb - Class in org.springframework.integration.mongodb.dsl
-
Factory class for building MongoDb components.
- MongoDbChangeStreamMessageProducer - Class in org.springframework.integration.mongodb.inbound
-
A
MessageProducerSupport
for MongoDB Change Stream implementation. - MongoDbChangeStreamMessageProducer(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
Create an instance based on the provided
ReactiveMongoOperations
. - MongoDbChangeStreamMessageProducerSpec - Class in org.springframework.integration.mongodb.dsl
- MongoDbChangeStreamMessageProducerSpec(MongoDbChangeStreamMessageProducer) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
-
Construct a builder based on an initial
MongoDbChangeStreamMessageProducerSpec
. - MongoDbChannelMessageStore - Class in org.springframework.integration.mongodb.store
-
MongoDB
PriorityCapableChannelMessageStore
implementation. - MongoDbChannelMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- MongoDbChannelMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- MongoDbChannelMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- MongoDbChannelMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- MongoDbChannelMessageStore(MongoDatabaseFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- MongoDbChannelMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- mongoDbFactory - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- MongoDbInboundChannelAdapterParser - Class in org.springframework.integration.mongodb.config
-
Parser for MongoDb store inbound adapters.
- MongoDbInboundChannelAdapterParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbInboundChannelAdapterParser
- MongoDbMessageSource - Class in org.springframework.integration.mongodb.inbound
-
An instance of
MessageSource
which returns aMessage
with a payload which is the result of execution of aQuery
. - MongoDbMessageSource(MongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Create an instance with the provided
MongoOperations
and SpEL expression which should resolve to a Mongo 'query' string (see https://www.mongodb.org/display/DOCS/Querying). - MongoDbMessageSource(MongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Create an instance with the provided
MongoDatabaseFactory
and SpEL expression which should resolve to a MongoDb 'query' string (see https://www.mongodb.org/display/DOCS/Querying). - MongoDbMessageSourceSpec - Class in org.springframework.integration.mongodb.dsl
-
A
AbstractMongoDbMessageSourceSpec
implementation for aMongoDbMessageSource
. - MongoDbMessageSourceSpec(MongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbMessageSourceSpec
- MongoDbMessageSourceSpec(MongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbMessageSourceSpec
- MongoDbMessageStore - Class in org.springframework.integration.mongodb.store
-
An implementation of both the
MessageStore
andMessageGroupStore
strategies that relies upon MongoDB for persistence. - MongoDbMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
Create a MongoDbMessageStore using the provided
MongoDatabaseFactory
.and the default collection name. - MongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
Create a MongoDbMessageStore using the provided
MongoDatabaseFactory
and collection name. - MongoDbMetadataStore - Class in org.springframework.integration.mongodb.metadata
-
MongoDbMetadataStore implementation of
ConcurrentMetadataStore
. - MongoDbMetadataStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Configure the MongoDbMetadataStore by provided
MongoTemplate
and default collection name -MongoDbMetadataStore.DEFAULT_COLLECTION_NAME
. - MongoDbMetadataStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Configure the MongoDbMetadataStore by provided
MongoTemplate
and collection name. - MongoDbMetadataStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Configure the MongoDbMetadataStore by provided
MongoDatabaseFactory
and default collection name -MongoDbMetadataStore.DEFAULT_COLLECTION_NAME
. - MongoDbMetadataStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Configure the MongoDbMetadataStore by provided
MongoDatabaseFactory
and collection name. - MongoDbNamespaceHandler - Class in org.springframework.integration.mongodb.config
-
Namespace handler for Spring Integration's 'mongodb' namespace.
- MongoDbNamespaceHandler() - Constructor for class org.springframework.integration.mongodb.config.MongoDbNamespaceHandler
- MongoDbOutboundChannelAdapterParser - Class in org.springframework.integration.mongodb.config
-
Parser for Mongodb store outbound adapters.
- MongoDbOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbOutboundChannelAdapterParser
- MongoDbOutboundGateway - Class in org.springframework.integration.mongodb.outbound
-
Makes outbound operations to query a MongoDb database using a
MongoOperations
. - MongoDbOutboundGateway(MongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- MongoDbOutboundGateway(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- MongoDbOutboundGateway(MongoDatabaseFactory, MongoConverter) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- MongoDbOutboundGatewayParser - Class in org.springframework.integration.mongodb.config
-
Parser for MongoDb outbound gateways.
- MongoDbOutboundGatewayParser() - Constructor for class org.springframework.integration.mongodb.config.MongoDbOutboundGatewayParser
- MongoDbOutboundGatewaySpec - Class in org.springframework.integration.mongodb.dsl
-
A
MessageHandlerSpec
extension for the MongoDb Outbound endpointMongoDbOutboundGateway
. - MongoDbOutboundGatewaySpec(MongoOperations) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- MongoDbOutboundGatewaySpec(MongoDatabaseFactory, MongoConverter) - Constructor for class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- MongoDbStoringMessageHandler - Class in org.springframework.integration.mongodb.outbound
-
Implementation of
MessageHandler
which writes Message payload into a MongoDb collection identified by evaluation of theMongoDbStoringMessageHandler.collectionNameExpression
. - MongoDbStoringMessageHandler(MongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Will construct this instance using fully created and initialized instance of provided
MongoOperations
. - MongoDbStoringMessageHandler(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Will construct this instance using provided
MongoDatabaseFactory
. - MongoHeaders - Class in org.springframework.integration.mongodb.support
-
Pre-defined names and prefixes to be used for dealing with headers required by Mongo components.
- monoAwaitSingleOrNull(Mono<? extends T>, Object) - Static method in class org.springframework.integration.util.CoroutinesUtils
- moved(ServerSession, Path, Path, Collection<CopyOption>, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- mPut(Message<?>, Session<F>, File) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Put files from the provided directory to the remote server recursively.
- mPut(Message<?>, Session<FTPFile>, File) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- MPUT - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
-
(mput) Put multiple local files to the remote system.
- mputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
A
FileListFilter
that runs against the local file system view when usingMPUT
command. - mputFilterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Configure the
ExpressionFileListFilter
. - mputFilterFunction(Function<File, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Configure the
ExpressionFileListFilter
. - mqttBytesToPayload(MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Subclasses can override this method to convert the byte[] to a payload.
- MqttComponent<T> - Interface in org.springframework.integration.mqtt.core
-
A component that interfaces with MQTT.
- MqttConnectionFailedEvent - Class in org.springframework.integration.mqtt.event
-
The
MqttIntegrationEvent
to notify about lost connection to the server. - MqttConnectionFailedEvent(Object) - Constructor for class org.springframework.integration.mqtt.event.MqttConnectionFailedEvent
- MqttConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.mqtt.event.MqttConnectionFailedEvent
- mqttErrorOccurred(MqttException) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- mqttErrorOccurred(MqttException) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- mqttErrorOccurred(MqttException) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- MqttHeaderAccessor - Class in org.springframework.integration.mqtt.support
-
Helper for typed access to incoming MQTT message headers.
- MqttHeaderMapper - Class in org.springframework.integration.mqtt.support
-
The default
HeaderMapper
implementation for MQTT v5 message properties mapping. - MqttHeaderMapper() - Constructor for class org.springframework.integration.mqtt.support.MqttHeaderMapper
- MqttHeaders - Class in org.springframework.integration.mqtt.support
-
Spring Integration headers.
- MqttIntegrationEvent - Class in org.springframework.integration.mqtt.event
-
Base class for Mqtt Events.
- MqttIntegrationEvent(Object) - Constructor for class org.springframework.integration.mqtt.event.MqttIntegrationEvent
- MqttIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.mqtt.event.MqttIntegrationEvent
- MqttMessageConverter - Interface in org.springframework.integration.mqtt.support
-
Extension of
MessageConverter
allowing the topic to be added as a header. - MqttMessageDeliveredEvent - Class in org.springframework.integration.mqtt.event
-
An event emitted (when using aysnc) when the client indicates the message was delivered.
- MqttMessageDeliveredEvent(Object, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageDeliveredEvent
- MqttMessageDeliveryEvent - Class in org.springframework.integration.mqtt.event
-
Base class for events related to message delivery.
- MqttMessageDeliveryEvent(Object, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
- MqttMessageDrivenChannelAdapterParser - Class in org.springframework.integration.mqtt.config.xml
-
The MqttAdapter Message Driven Channel adapter parser.
- MqttMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttMessageDrivenChannelAdapterParser
- MqttMessageSentEvent - Class in org.springframework.integration.mqtt.event
-
An event emitted (when using async) when the client indicates that a message has been sent.
- MqttMessageSentEvent(Object, Message<?>, String, int, String, int) - Constructor for class org.springframework.integration.mqtt.event.MqttMessageSentEvent
- MqttNamespaceHandler - Class in org.springframework.integration.mqtt.config.xml
-
The namespace handler for the MqttAdapter namespace.
- MqttNamespaceHandler() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttNamespaceHandler
- MqttOutboundChannelAdapterParser - Class in org.springframework.integration.mqtt.config.xml
-
The parser for the MqttAdapter Outbound Channel Adapter.
- MqttOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
- MqttPahoClientFactory - Interface in org.springframework.integration.mqtt.core
- MqttPahoComponent - Interface in org.springframework.integration.mqtt.core
-
An extension of
MqttComponent
for Eclipse Paho components. - MqttPahoMessageDrivenChannelAdapter - Class in org.springframework.integration.mqtt.inbound
-
Eclipse Paho Implementation.
- MqttPahoMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Use this constructor when you don't need additional
MqttConnectOptions
. - MqttPahoMessageDrivenChannelAdapter(String, String, MqttPahoClientFactory, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Use this constructor for a single url (although it may be overridden if the server URI(s) are provided by the
MqttConnectOptions.getServerURIs()
provided by theMqttPahoClientFactory
). - MqttPahoMessageDrivenChannelAdapter(String, MqttPahoClientFactory, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Use this constructor if the server URI(s) are provided by the
MqttConnectOptions.getServerURIs()
provided by theMqttPahoClientFactory
. - MqttPahoMessageDrivenChannelAdapter(ClientManager<IMqttAsyncClient, MqttConnectOptions>, String...) - Constructor for class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Use this constructor when you need to use a single
ClientManager
(for instance, to reuse an MQTT connection). - MqttPahoMessageHandler - Class in org.springframework.integration.mqtt.outbound
-
Eclipse Paho Implementation.
- MqttPahoMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Use this constructor when you don't need additional
MqttConnectOptions
. - MqttPahoMessageHandler(String, String, MqttPahoClientFactory) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Use this constructor for a single url (although it may be overridden if the server URI(s) are provided by the
MqttConnectOptions.getServerURIs()
provided by theMqttPahoClientFactory
). - MqttPahoMessageHandler(String, MqttPahoClientFactory) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Use this constructor if the server URI(s) are provided by the
MqttConnectOptions.getServerURIs()
provided by theMqttPahoClientFactory
. - MqttPahoMessageHandler(ClientManager<IMqttAsyncClient, MqttConnectOptions>) - Constructor for class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Use this constructor when you need to use a single
ClientManager
(for instance, to reuse an MQTT connection). - MqttProtocolErrorEvent - Class in org.springframework.integration.mqtt.event
-
The even representing an MQTT error occured during client interaction.
- MqttProtocolErrorEvent(Object, MqttException) - Constructor for class org.springframework.integration.mqtt.event.MqttProtocolErrorEvent
- MqttSubscribedEvent - Class in org.springframework.integration.mqtt.event
- MqttSubscribedEvent(Object, String) - Constructor for class org.springframework.integration.mqtt.event.MqttSubscribedEvent
- MqttUtils - Class in org.springframework.integration.mqtt.support
-
MQTT Utilities.
- Mqttv3ClientManager - Class in org.springframework.integration.mqtt.core
-
A client manager implementation for MQTT v3 protocol.
- Mqttv3ClientManager(String, String) - Constructor for class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- Mqttv3ClientManager(MqttConnectOptions, String) - Constructor for class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- Mqttv5ClientManager - Class in org.springframework.integration.mqtt.core
-
A client manager implementation for MQTT v5 protocol.
- Mqttv5ClientManager(String, String) - Constructor for class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- Mqttv5ClientManager(MqttConnectionOptions, String) - Constructor for class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- Mqttv5PahoMessageDrivenChannelAdapter - Class in org.springframework.integration.mqtt.inbound
-
The
AbstractMqttMessageDrivenChannelAdapter
implementation for MQTT v5. - Mqttv5PahoMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- Mqttv5PahoMessageDrivenChannelAdapter(MqttConnectionOptions, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- Mqttv5PahoMessageDrivenChannelAdapter(ClientManager<IMqttAsyncClient, MqttConnectionOptions>, String...) - Constructor for class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
-
Use this constructor when you need to use a single
ClientManager
(for instance, to reuse an MQTT connection). - Mqttv5PahoMessageHandler - Class in org.springframework.integration.mqtt.outbound
-
The
AbstractMqttMessageHandler
implementation for MQTT v5. - Mqttv5PahoMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- Mqttv5PahoMessageHandler(MqttConnectionOptions, String) - Constructor for class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- Mqttv5PahoMessageHandler(ClientManager<IMqttAsyncClient, MqttConnectionOptions>) - Constructor for class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
-
Use this constructor when you need to use a single
ClientManager
(for instance, to reuse an MQTT connection). - MSGID - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- MulticastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
-
Channel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.
- MulticastReceivingChannelAdapter(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
-
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
- MulticastReceivingChannelAdapter(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
-
Constructs a MulticastReceivingChannelAdapter that listens for packets on the specified multichannel address (group) and port.
- MulticastSendingMessageHandler - Class in org.springframework.integration.ip.udp
-
A
MessageHandler
implementation that maps a Message into a UDP datagram packet and sends that to the specified multicast address (224.0.0.0 to 239.255.255.255) and port. - MulticastSendingMessageHandler(String) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Construct MulticastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
- MulticastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port.
- MulticastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the lengthCheck option (if set, a length is prepended to the packet and checked at the destination).
- MulticastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
- MulticastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Constructs a MulticastSendingMessageHandler to send data to the multicast address/port and enables setting the acknowledge option, where the destination sends a receipt acknowledgment.
- MulticastSendingMessageHandler(Expression) - Constructor for class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
Construct MulticastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
- MULTIPART_MODE - Static variable in class org.springframework.integration.mail.MailHeaders
- MultipartAwareFormHttpMessageConverter - Class in org.springframework.integration.http.converter
-
An
HttpMessageConverter
implementation that delegates to an instance ofAllEncompassingFormHttpMessageConverter
while adding the capability to readmultipart/form-data
content in an HTTP request. - MultipartAwareFormHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
- MultipartFileReader<T> - Interface in org.springframework.integration.http.multipart
-
Strategy for reading
MultipartFile
content. - MultipartHttpInputMessage - Class in org.springframework.integration.http.multipart
- MultipartHttpInputMessage(MultipartHttpServletRequest) - Constructor for class org.springframework.integration.http.multipart.MultipartHttpInputMessage
- multipartMode(int) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a multipart mode to use.
- multipartModeExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set an expression that is evaluated to determine a multipart mode to use.
- multipartModeFunction(Function<Message<P>, Integer>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that is invoked to determine a multipart mode to use.
- multipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
-
Specify the
MultipartResolver
to use when checking requests. - multiSend(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpOutboundChannelAdapterSpec
- MutableMessage<T> - Class in org.springframework.integration.support
-
An implementation of
Message
with a generic payload. - MutableMessage(T) - Constructor for class org.springframework.integration.support.MutableMessage
- MutableMessage(T, Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessage
- MutableMessage(T, MutableMessageHeaders) - Constructor for class org.springframework.integration.support.MutableMessage
- MutableMessageBuilder<T> - Class in org.springframework.integration.support
-
Specialized message builder that can be used within a component to avoid the overhead of having to build multiple messages for mutations within that component.
- MutableMessageBuilderFactory - Class in org.springframework.integration.support
- MutableMessageBuilderFactory() - Constructor for class org.springframework.integration.support.MutableMessageBuilderFactory
- MutableMessageHeaders - Class in org.springframework.integration.support
-
A MessageHeaders that permits direct access to and modification of the header map.
- MutableMessageHeaders(Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessageHeaders
- MutableMessageHeaders(Map<String, Object>, UUID, Long) - Constructor for class org.springframework.integration.support.MutableMessageHeaders
- MutableMessageJacksonDeserializer - Class in org.springframework.integration.support.json
-
The
MessageJacksonDeserializer
implementation for theMutableMessage
. - MutableMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
- mv(Message<?>, Session<F>, String, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Move one remote path to another.
- mv(Message<?>, Session<FTPFile>, String, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- MV - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
-
(mv) Move (rename) a remote file.
- MySqlChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
- MySqlChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form