Uses of Interface
org.springframework.integration.core.MessageProducer
Packages that use 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.
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.
-
Uses of MessageProducer in org.springframework.integration.aggregator
Classes in org.springframework.integration.aggregator that implement MessageProducerModifier and TypeClassDescriptionclassAbstract Message handler that holds a buffer of correlated messages in aMessageStore.classAggregator specific implementation ofAbstractCorrelatingMessageHandler.classA message handler that suspends the thread until a message with corresponding correlation is passed into thetriggermethod or the timeout occurs.classTheAbstractMessageProducingHandlerimplementation for aggregation logic based on Reactor'sFlux.groupBy(java.util.function.Function<? super T, ? extends K>)andFlux.window(int)operators.classResequencer specific implementation ofAbstractCorrelatingMessageHandler. -
Uses of MessageProducer in org.springframework.integration.amqp.inbound
Classes in org.springframework.integration.amqp.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAdapter 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
Classes in org.springframework.integration.amqp.outbound that implement MessageProducerModifier and TypeClassDescriptionclassA baseAbstractReplyProducingMessageHandlerextension for AMQP message handlers.classAdapter that converts and sends Messages to an AMQP Exchange.classAn 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
Classes in org.springframework.integration.camel.outbound that implement MessageProducerModifier and TypeClassDescriptionclassAMessageHandlerfor calling Apache Camel route and produce (optionally) a reply. -
Uses of MessageProducer in org.springframework.integration.cassandra.outbound
Classes in org.springframework.integration.cassandra.outbound that implement MessageProducerModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlerimplementation for Cassandra outbound operations. -
Uses of MessageProducer in org.springframework.integration.dsl
Methods in org.springframework.integration.dsl with parameters of type MessageProducerModifier and TypeMethodDescriptionprotected voidBaseIntegrationFlowDefinition.checkReuse(MessageProducer replyHandler) -
Uses of MessageProducer in org.springframework.integration.endpoint
Classes in org.springframework.integration.endpoint that implement MessageProducerModifier and TypeClassDescriptionclassAMessageProducerSupportsub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.classA support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.classTheMessageProducerSupportto adapt a providedMessageSourceinto aFluxand let it be subscribed in theMessageProducerSupport.subscribeToPublisher(org.reactivestreams.Publisher<? extends org.springframework.messaging.Message<?>>). -
Uses of MessageProducer in org.springframework.integration.event.inbound
Classes in org.springframework.integration.event.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAn inbound Channel Adapter that implementsGenericApplicationListenerand passes SpringApplicationEventswithin messages. -
Uses of MessageProducer in org.springframework.integration.file
Classes in org.springframework.integration.file that implement MessageProducerModifier and TypeClassDescriptionclassAMessageHandlerimplementation that writes the Message payload to a file. -
Uses of MessageProducer in org.springframework.integration.file.remote.gateway
Classes in org.springframework.integration.file.remote.gateway that implement MessageProducerModifier and TypeClassDescriptionclassBase class for Outbound Gateways that perform remote file operations. -
Uses of MessageProducer in org.springframework.integration.file.splitter
Classes in org.springframework.integration.file.splitter that implement MessageProducerModifier and TypeClassDescriptionclassTheAbstractMessageSplitterimplementation to split theFileMessage payload to lines. -
Uses of MessageProducer in org.springframework.integration.file.tail
Classes in org.springframework.integration.file.tail that implement MessageProducerModifier and TypeClassDescriptionclassFile tailer that delegates to the Apache Commons Tailer.classBase class for file tailing inbound adapters.classA file tailing message producer that delegates to the OS tail program. -
Uses of MessageProducer in org.springframework.integration.filter
Classes in org.springframework.integration.filter that implement MessageProducer -
Uses of MessageProducer in org.springframework.integration.ftp.gateway
Classes in org.springframework.integration.ftp.gateway that implement MessageProducerModifier and TypeClassDescriptionclassOutbound Gateway for performing remote file operations via FTP/FTPS. -
Uses of MessageProducer in org.springframework.integration.gateway
Classes in org.springframework.integration.gateway that implement MessageProducerModifier and TypeClassDescriptionclassTheAbstractReplyProducingMessageHandlerimplementation for mid-flow Gateway. -
Uses of MessageProducer in org.springframework.integration.graphql.outbound
Classes in org.springframework.integration.graphql.outbound that implement MessageProducerModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlercapable of fielding GraphQL Query, Mutation and Subscription requests. -
Uses of MessageProducer in org.springframework.integration.handler
Classes in org.springframework.integration.handler that implement MessageProducerModifier and TypeClassDescriptionclassThe baseAbstractMessageHandlerimplementation for theMessageProducer.classBase class for MessageHandlers that are capable of producing replies.classclassA simple MessageHandler implementation that passes the request Message directly to the output channel without modifying it.classAMessageHandlerthat is capable of delaying the continuation of a Message flow based on the result of evaluationdelayExpressionon an inboundMessageor a default delay value configured on this handler.classA compositeMessageHandlerimplementation that invokes a chain of MessageHandler instances in order.classTheAbstractReplyProducingMessageHandlerwrapper around rawMessageHandlerfor request-reply scenarios, e.g.class -
Uses of MessageProducer in org.springframework.integration.hazelcast.inbound
Classes in org.springframework.integration.hazelcast.inbound that implement MessageProducerModifier and TypeClassDescriptionclassHazelcast Base Event-Driven Message Producer.classHazelcast Cluster Monitor Event Driven Message Producer is a message producer which enablesHazelcastClusterMonitorMessageProducer.HazelcastClusterMonitorListenerlistener in order to listen cluster related events and sends events to related channel.classHazelcast Continuous Query Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListenerwith aSqlPredicatein order to listen related distributed map events in the light of defined predicate and sends events to related channel.classHazelcast Event Driven Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListener,HazelcastEventDrivenMessageProducer.HazelcastItemListenerandHazelcastEventDrivenMessageProducer.HazelcastMessageListenerlisteners in order to listen related cache events and sends events to related channel. -
Uses of MessageProducer in org.springframework.integration.http.outbound
Classes in org.springframework.integration.http.outbound that implement MessageProducerModifier and TypeClassDescriptionclassBase class for http outbound adapter/gateway.classAMessageHandlerimplementation that executes HTTP requests by delegating to aRestTemplateinstance. -
Uses of MessageProducer in org.springframework.integration.ip
Classes in org.springframework.integration.ip that implement MessageProducerModifier and TypeClassDescriptionclassBase class for inbound TCP/UDP Channel Adapters. -
Uses of MessageProducer in org.springframework.integration.ip.tcp
Classes in org.springframework.integration.ip.tcp that implement MessageProducerModifier and TypeClassDescriptionclassTCP outbound gateway that uses a client connection factory.classTcp 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
Classes in org.springframework.integration.ip.udp that implement MessageProducerModifier and TypeClassDescriptionclassChannel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.classA channel adapter to receive incoming UDP packets. -
Uses of MessageProducer in org.springframework.integration.jdbc
Classes in org.springframework.integration.jdbc that implement MessageProducerModifier and TypeClassDescriptionclassclassAnAbstractReplyProducingMessageHandlerimplementation for performing RDBMS stored procedures which return results. -
Uses of MessageProducer in org.springframework.integration.jms
Classes in org.springframework.integration.jms that implement MessageProducerModifier and TypeClassDescriptionclassA message-driven endpoint that receive JMS messages, converts them into Spring Integration Messages, and then sends the result to a channel.classAn outbound Messaging Gateway for request/reply JMS. -
Uses of MessageProducer in org.springframework.integration.jmx
Classes in org.springframework.integration.jmx that implement MessageProducerModifier and TypeClassDescriptionclassA JMXNotificationListenerimplementation that will send Messages containing the JMXNotificationinstances as their payloads.classAMessageHandlerimplementation for invoking JMX operations based on the Message sent to itsAbstractMessageHandler.handleMessage(Message)method. -
Uses of MessageProducer in org.springframework.integration.jpa.outbound
Classes in org.springframework.integration.jpa.outbound that implement MessageProducerModifier and TypeClassDescriptionclassThe 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
Classes in org.springframework.integration.kafka.inbound that implement MessageProducerModifier and TypeClassDescriptionclassMessage-driven channel adapter. -
Uses of MessageProducer in org.springframework.integration.kafka.outbound
Classes in org.springframework.integration.kafka.outbound that implement MessageProducerModifier and TypeClassDescriptionclassA Message Handler for Apache Kafka; when supplied with aReplyingKafkaTemplateit is used as the handler in an outbound gateway. -
Uses of MessageProducer in org.springframework.integration.mail
Classes in org.springframework.integration.mail that implement MessageProducerModifier and TypeClassDescriptionclassAn 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
Classes in org.springframework.integration.mongodb.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAMessageProducerSupportfor MongoDB Change Stream implementation. -
Uses of MessageProducer in org.springframework.integration.mongodb.outbound
Classes in org.springframework.integration.mongodb.outbound that implement MessageProducerModifier and TypeClassDescriptionclassMakes outbound operations to query a MongoDb database using aMongoOperations. -
Uses of MessageProducer in org.springframework.integration.mqtt.inbound
Classes in org.springframework.integration.mqtt.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAbstract class for MQTT Message-Driven Channel Adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageDrivenChannelAdapterimplementation for MQTT v5. -
Uses of MessageProducer in org.springframework.integration.redis.inbound
Classes in org.springframework.integration.redis.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAMessageProducerSupportfor reading messages from a Redis Stream and publishing them into the provided output channel.classclass -
Uses of MessageProducer in org.springframework.integration.redis.outbound
Classes in org.springframework.integration.redis.outbound that implement MessageProducerModifier and TypeClassDescriptionclassThe 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
Classes in org.springframework.integration.rsocket.outbound that implement MessageProducerModifier and TypeClassDescriptionclassAn Outbound Messaging Gateway for RSocket requests. -
Uses of MessageProducer in org.springframework.integration.scattergather
Classes in org.springframework.integration.scattergather that implement MessageProducerModifier and TypeClassDescriptionclassTheMessageHandlerimplementation for the Scatter-Gather EIP pattern. -
Uses of MessageProducer in org.springframework.integration.sftp.gateway
Classes in org.springframework.integration.sftp.gateway that implement MessageProducerModifier and TypeClassDescriptionclassOutbound Gateway for performing remote file operations via SFTP. -
Uses of MessageProducer in org.springframework.integration.smb.outbound
Classes in org.springframework.integration.smb.outbound that implement MessageProducerModifier and TypeClassDescriptionclassOutbound Gateway for performing remote file operations via SMB. -
Uses of MessageProducer in org.springframework.integration.splitter
Classes in org.springframework.integration.splitter that implement MessageProducerModifier and TypeClassDescriptionclassBase class for Message-splitting handlers.classThe default Message Splitter implementation.classA Message Splitter implementation that evaluates the specified SpEL expression.classA Message Splitter implementation that invokes the specified method on the given object. -
Uses of MessageProducer in org.springframework.integration.stomp.inbound
Classes in org.springframework.integration.stomp.inbound that implement MessageProducerModifier and TypeClassDescriptionclassTheMessageProducerSupportfor STOMP protocol to handle STOMP frames from provided destination and send messages to theoutputChannel. -
Uses of MessageProducer in org.springframework.integration.syslog.inbound
Classes in org.springframework.integration.syslog.inbound that implement MessageProducerModifier and TypeClassDescriptionclassBase support class for inbound channel adapters.classTCP implementation of a syslog inbound channel adapter.classUDP implementation of a syslog inbound channel adapter. -
Uses of MessageProducer in org.springframework.integration.test.mock
Classes in org.springframework.integration.test.mock that implement MessageProducerModifier and TypeClassDescriptionclassTheAbstractMessageProducingHandlerextension for the mocking purpose in tests. -
Uses of MessageProducer in org.springframework.integration.transformer
Classes in org.springframework.integration.transformer that implement MessageProducerModifier and TypeClassDescriptionclassContent 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.classA reply-producingMessageHandlerthat delegates to aTransformerinstance to modify the receivedMessageand sends the result to its output channel. -
Uses of MessageProducer in org.springframework.integration.webflux.outbound
Classes in org.springframework.integration.webflux.outbound that implement MessageProducerModifier and TypeClassDescriptionclassAMessageHandlerimplementation that executes HTTP requests by delegating to a ReactiveWebClientinstance. -
Uses of MessageProducer in org.springframework.integration.websocket.inbound
Classes in org.springframework.integration.websocket.inbound that implement MessageProducerModifier and TypeClassDescriptionclassTheMessageProducerSupportfor inbound WebSocket messages. -
Uses of MessageProducer in org.springframework.integration.ws
Classes in org.springframework.integration.ws that implement MessageProducerModifier and TypeClassDescriptionclassBase class for outbound Web Service-invoking Messaging Gateways.classAn outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.classAn outbound Messaging Gateway for invoking a Web Service. -
Uses of MessageProducer in org.springframework.integration.xml.splitter
Classes in org.springframework.integration.xml.splitter that implement MessageProducerModifier and TypeClassDescriptionclassMessage Splitter that uses anXPathExpressionto split aDocument,FileorStringpayload into aNodeList. -
Uses of MessageProducer in org.springframework.integration.xmpp.core
Classes in org.springframework.integration.xmpp.core that implement MessageProducer -
Uses of MessageProducer in org.springframework.integration.xmpp.inbound
Classes in org.springframework.integration.xmpp.inbound that implement MessageProducerModifier and TypeClassDescriptionclassThis component logs in as a user and forwards any messages to that user on to downstream components.classAn 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
Classes in org.springframework.integration.zeromq.inbound that implement MessageProducerModifier and TypeClassDescriptionclassAMessageProducerSupportimplementation for consuming messages from ZeroMq socket.