Uses of Interface
org.springframework.integration.core.MessageProducer
Package
Description
Provides classes related to message aggregation.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes for Apache Camel outbound channel adapters.
Provides classes supporting Cassandra outbound endpoints.
Provides classes for the Debezium inbound channel adapters.
Root package of the Spring Integration Java DSL.
Provides core classes related to Endpoints.
Provides classes supporting inbound endpoints.
Base package for File support.
Provides classes supporting remote file gateways.
Provides implementations of
AbstractMessageSplitter
.Classes used for tailing file system files.
Provides classes supporting the filter pattern.
Provides classes supporting FTP gateways.
Provides classes supporting messaging gateways.
Provides classes for GraphQL outbound channel adapters.
Provides classes implementing various types of message handler.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Base package for IP (TCP/UDP) Support.
Base package for TCP Support.
Base package for UDP support.
Root package of the Spring Integration JDBC module, which contains various
JDBC and Stored Procedure/Function supporting components.
Base package for JMS Support.
Base package for JMX support.
Provides Spring Integration components for doing outbound operations.
Provides Spring Integration inbound components for Apache Kafka.
Provides Spring Integration outbound components for Apache Kafka.
Base package for Mail support.
Provides classes related to the Mongo inbound channel adapters
Provides classes related to the Mongo outbound channel adapters
Provides inbound Spring Integration MqttAdapter components.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes representing outbound RSocket components.
Provides classes supporting the Scatter-Gather pattern.
Provides classes supporting SFTP gateways.
Outbound Channel Adapter implementations for SMB protocol.
Provides classes supporting the splitter pattern.
Provides classes which represent inbound STOMP components.
Provides classes for inbound endpoints.
Utilities for mocking integration components.
Contains core-implementation of various Transformers which includes Enrichers
and Filters.
Provides classes supporting outbound endpoints.
Provides classes which represent inbound WebSocket components.
Provides several inbound and outbound Web Service components.
Provides implementations of
AbstractMessageSplitter
.Provides classes shared across all XMPP components.
Provides XMPP inbound Endpoint implementations that extend
AbstractXmppConnectionAwareEndpoint
.Provides classes for inbound channel adapters over ZeroMQ.
Classes to support Splitter pattern for Zip.
-
Uses of MessageProducer in org.springframework.integration.aggregator
Modifier and TypeClassDescriptionclass
Abstract Message handler that holds a buffer of correlated messages in aMessageStore
.class
Aggregator specific implementation ofAbstractCorrelatingMessageHandler
.class
A message handler that suspends the thread until a message with corresponding correlation is passed into thetrigger
method or the timeout occurs.class
TheAbstractMessageProducingHandler
implementation for aggregation logic based on Reactor'sFlux.groupBy(java.util.function.Function<? super T, ? extends K>)
andFlux.window(int)
operators.class
Resequencer specific implementation ofAbstractCorrelatingMessageHandler
. -
Uses of MessageProducer in org.springframework.integration.amqp.inbound
Modifier and TypeClassDescriptionclass
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel. -
Uses of MessageProducer in org.springframework.integration.amqp.outbound
Modifier and TypeClassDescriptionclass
A baseAbstractReplyProducingMessageHandler
extension for AMQP message handlers.class
Adapter that converts and sends Messages to an AMQP Exchange.class
An outbound gateway where the sending thread is released immediately and the reply is sent on the async template's listener container thread. -
Uses of MessageProducer in org.springframework.integration.camel.outbound
Modifier and TypeClassDescriptionclass
AMessageHandler
for calling Apache Camel route and produce (optionally) a reply. -
Uses of MessageProducer in org.springframework.integration.cassandra.outbound
Modifier and TypeClassDescriptionclass
AnAbstractReplyProducingMessageHandler
implementation for Cassandra outbound operations. -
Uses of MessageProducer in org.springframework.integration.debezium.inbound
Modifier and TypeClassDescriptionclass
Debezium Change Event Channel Adapter. -
Uses of MessageProducer in org.springframework.integration.dsl
Modifier and TypeMethodDescriptionprotected void
BaseIntegrationFlowDefinition.checkReuse
(MessageProducer replyHandler) -
Uses of MessageProducer in org.springframework.integration.endpoint
Modifier and TypeClassDescriptionclass
AMessageProducerSupport
sub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.class
A support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.class
TheMessageProducerSupport
to adapt a providedMessageSource
into aFlux
and let it be subscribed in theMessageProducerSupport.subscribeToPublisher(org.reactivestreams.Publisher<? extends org.springframework.messaging.Message<?>>)
. -
Uses of MessageProducer in org.springframework.integration.event.inbound
Modifier and TypeClassDescriptionclass
An inbound Channel Adapter that implementsGenericApplicationListener
and passes SpringApplicationEvents
within messages. -
Uses of MessageProducer in org.springframework.integration.file
Modifier and TypeClassDescriptionclass
AMessageHandler
implementation that writes the Message payload to a file. -
Uses of MessageProducer in org.springframework.integration.file.remote.gateway
Modifier and TypeClassDescriptionclass
Base class for Outbound Gateways that perform remote file operations. -
Uses of MessageProducer in org.springframework.integration.file.splitter
Modifier and TypeClassDescriptionclass
TheAbstractMessageSplitter
implementation to split theFile
Message payload to lines. -
Uses of MessageProducer in org.springframework.integration.file.tail
Modifier and TypeClassDescriptionclass
File tailer that delegates to the Apache Commons Tailer.class
Base class for file tailing inbound adapters.class
A file tailing message producer that delegates to the OS tail program. -
Uses of MessageProducer in org.springframework.integration.filter
-
Uses of MessageProducer in org.springframework.integration.ftp.gateway
Modifier and TypeClassDescriptionclass
Outbound Gateway for performing remote file operations via FTP/FTPS. -
Uses of MessageProducer in org.springframework.integration.gateway
Modifier and TypeClassDescriptionclass
TheAbstractReplyProducingMessageHandler
implementation for mid-flow Gateway. -
Uses of MessageProducer in org.springframework.integration.graphql.outbound
Modifier and TypeClassDescriptionclass
AnAbstractReplyProducingMessageHandler
capable of fielding GraphQL Query, Mutation and Subscription requests. -
Uses of MessageProducer in org.springframework.integration.handler
Modifier and TypeClassDescriptionclass
The baseAbstractMessageHandler
implementation for theMessageProducer
.class
Base class for MessageHandlers that are capable of producing replies.class
class
A simple MessageHandler implementation that passes the request Message directly to the output channel without modifying it.class
AMessageHandler
that is capable of delaying the continuation of a Message flow based on the result of evaluationdelayExpression
on an inboundMessage
or a default delay value configured on this handler.class
A compositeMessageHandler
implementation that invokes a chain of MessageHandler instances in order.class
TheAbstractReplyProducingMessageHandler
wrapper around rawMessageHandler
for request-reply scenarios, e.g.class
-
Uses of MessageProducer in org.springframework.integration.hazelcast.inbound
Modifier and TypeClassDescriptionclass
Hazelcast Base Event-Driven Message Producer.class
Hazelcast Cluster Monitor Event Driven Message Producer is a message producer which enablesHazelcastClusterMonitorMessageProducer.HazelcastClusterMonitorListener
listener in order to listen cluster related events and sends events to related channel.class
Hazelcast Continuous Query Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListener
with aSqlPredicate
in order to listen related distributed map events in the light of defined predicate and sends events to related channel.class
Hazelcast Event Driven Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListener
,HazelcastEventDrivenMessageProducer.HazelcastItemListener
andHazelcastEventDrivenMessageProducer.HazelcastMessageListener
listeners in order to listen related cache events and sends events to related channel. -
Uses of MessageProducer in org.springframework.integration.http.outbound
Modifier and TypeClassDescriptionclass
Base class for http outbound adapter/gateway.class
AMessageHandler
implementation that executes HTTP requests by delegating to aRestTemplate
instance. -
Uses of MessageProducer in org.springframework.integration.ip
Modifier and TypeClassDescriptionclass
Base class for inbound TCP/UDP Channel Adapters. -
Uses of MessageProducer in org.springframework.integration.ip.tcp
Modifier and TypeClassDescriptionclass
TCP outbound gateway that uses a client connection factory.class
Tcp inbound channel adapter using a TcpConnection to receive data - if the connection factory is a server factory, this Listener owns the connections. -
Uses of MessageProducer in org.springframework.integration.ip.udp
Modifier and TypeClassDescriptionclass
Channel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.class
A channel adapter to receive incoming UDP packets. -
Uses of MessageProducer in org.springframework.integration.jdbc
Modifier and TypeClassDescriptionclass
class
AnAbstractReplyProducingMessageHandler
implementation for performing RDBMS stored procedures which return results. -
Uses of MessageProducer in org.springframework.integration.jms
Modifier and TypeClassDescriptionclass
A message-driven endpoint that receive JMS messages, converts them into Spring Integration Messages, and then sends the result to a channel.class
An outbound Messaging Gateway for request/reply JMS. -
Uses of MessageProducer in org.springframework.integration.jmx
Modifier and TypeClassDescriptionclass
A JMXNotificationListener
implementation that will send Messages containing the JMXNotification
instances as their payloads.class
AMessageHandler
implementation for invoking JMX operations based on the Message sent to itsAbstractMessageHandler.handleMessage(Message)
method. -
Uses of MessageProducer in org.springframework.integration.jpa.outbound
Modifier and TypeClassDescriptionclass
The Jpa Outbound Gateway will allow you to make outbound operations to either: submit (insert, delete) data to a database using JPA retrieve (select) data from a database Depending on the selectedOutboundGatewayType
, the outbound gateway will use either theJpaExecutor
's poll method or its executeOutboundJpaOperation method. -
Uses of MessageProducer in org.springframework.integration.kafka.inbound
Modifier and TypeClassDescriptionclass
Message-driven channel adapter. -
Uses of MessageProducer in org.springframework.integration.kafka.outbound
Modifier and TypeClassDescriptionclass
A Message Handler for Apache Kafka; when supplied with aReplyingKafkaTemplate
it is used as the handler in an outbound gateway. -
Uses of MessageProducer in org.springframework.integration.mail
Modifier and TypeClassDescriptionclass
An event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177). -
Uses of MessageProducer in org.springframework.integration.mongodb.inbound
Modifier and TypeClassDescriptionclass
AMessageProducerSupport
for MongoDB Change Stream implementation. -
Uses of MessageProducer in org.springframework.integration.mongodb.outbound
Modifier and TypeClassDescriptionclass
Makes outbound operations to query a MongoDb database using aMongoOperations
. -
Uses of MessageProducer in org.springframework.integration.mqtt.inbound
Modifier and TypeClassDescriptionclass
Abstract class for MQTT Message-Driven Channel Adapters.class
Eclipse Paho Implementation.class
TheAbstractMqttMessageDrivenChannelAdapter
implementation for MQTT v5. -
Uses of MessageProducer in org.springframework.integration.redis.inbound
Modifier and TypeClassDescriptionclass
AMessageProducerSupport
for reading messages from a Redis Stream and publishing them into the provided output channel.class
class
-
Uses of MessageProducer in org.springframework.integration.redis.outbound
Modifier and TypeClassDescriptionclass
The Gateway component implementation to perform Redis commands with provided arguments and to return command result.class
-
Uses of MessageProducer in org.springframework.integration.rsocket.outbound
Modifier and TypeClassDescriptionclass
An Outbound Messaging Gateway for RSocket requests. -
Uses of MessageProducer in org.springframework.integration.scattergather
Modifier and TypeClassDescriptionclass
TheMessageHandler
implementation for the Scatter-Gather EIP pattern. -
Uses of MessageProducer in org.springframework.integration.sftp.gateway
Modifier and TypeClassDescriptionclass
Outbound Gateway for performing remote file operations via SFTP. -
Uses of MessageProducer in org.springframework.integration.smb.outbound
Modifier and TypeClassDescriptionclass
Outbound Gateway for performing remote file operations via SMB. -
Uses of MessageProducer in org.springframework.integration.splitter
Modifier and TypeClassDescriptionclass
Base class for Message-splitting handlers.class
The default Message Splitter implementation.class
A Message Splitter implementation that evaluates the specified SpEL expression.class
A Message Splitter implementation that invokes the specified method on the given object. -
Uses of MessageProducer in org.springframework.integration.stomp.inbound
Modifier and TypeClassDescriptionclass
TheMessageProducerSupport
for STOMP protocol to handle STOMP frames from provided destination and send messages to theoutputChannel
. -
Uses of MessageProducer in org.springframework.integration.syslog.inbound
Modifier and TypeClassDescriptionclass
Base support class for inbound channel adapters.class
TCP implementation of a syslog inbound channel adapter.class
UDP implementation of a syslog inbound channel adapter. -
Uses of MessageProducer in org.springframework.integration.test.mock
Modifier and TypeClassDescriptionclass
TheAbstractMessageProducingHandler
extension for the mocking purpose in tests. -
Uses of MessageProducer in org.springframework.integration.transformer
Modifier and TypeClassDescriptionclass
Content Enricher is a Message Transformer that can augment a message's payload with either static values or by optionally invoking a downstream message flow via its request channel and then applying values from the reply Message to the original payload.class
A reply-producingMessageHandler
that delegates to aTransformer
instance to modify the receivedMessage
and sends the result to its output channel. -
Uses of MessageProducer in org.springframework.integration.webflux.outbound
Modifier and TypeClassDescriptionclass
AMessageHandler
implementation that executes HTTP requests by delegating to a ReactiveWebClient
instance. -
Uses of MessageProducer in org.springframework.integration.websocket.inbound
Modifier and TypeClassDescriptionclass
TheMessageProducerSupport
for inbound WebSocket messages. -
Uses of MessageProducer in org.springframework.integration.ws
Modifier and TypeClassDescriptionclass
Base class for outbound Web Service-invoking Messaging Gateways.class
An outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.class
An outbound Messaging Gateway for invoking a Web Service. -
Uses of MessageProducer in org.springframework.integration.xml.splitter
Modifier and TypeClassDescriptionclass
Message Splitter that uses anXPathExpression
to split aDocument
,File
orString
payload into aNodeList
. -
Uses of MessageProducer in org.springframework.integration.xmpp.core
-
Uses of MessageProducer in org.springframework.integration.xmpp.inbound
Modifier and TypeClassDescriptionclass
This component logs in as a user and forwards any messages to that user on to downstream components.class
An inbound endpoint that is able to login and then emit particular Presence event occurs within the logged-in user'sRoster
. -
Uses of MessageProducer in org.springframework.integration.zeromq.inbound
Modifier and TypeClassDescriptionclass
AMessageProducerSupport
implementation for consuming messages from ZeroMq socket. -
Uses of MessageProducer in org.springframework.integration.zip.splitter