Uses of Interface
org.springframework.integration.context.ComponentSourceAware
Packages that use ComponentSourceAware
Package
Description
Provides classes related to message aggregation.
Provides classes related to AMQP-backed channels.
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 representing various channel types.
Provides base classes for the 
Codec abstraction.Provides classes relating to application context configuration.
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.
Provides classes supporting outbound endpoints.
Base package for File support.
Provides classes supporting remote file gateways.
Provides classes supporting remote file message handlers.
Provides implementations of
 
AbstractMessageSplitter.Classes used for tailing file system files.
Provides classes supporting the filter pattern.
Provides classes supporting FTP gateways.
Provides classes for the FTP outbound channel adapter.
Provides classes supporting messaging gateways.
Provides classes for GraphQL outbound channel adapters.
Provides classes implementing various types of message handler.
Provides classes that are used to advise
 
MessageHandlers with
 cross-cutting concerns.Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Base package for IP (TCP/UDP) Support.
Base package for TCP Support.
All things related to tcp connections - client and
 server factories; listener and sender interfaces.
Base package for UDP support.
Root package of the Spring Integration JDBC module, which contains various
 JDBC and Stored Procedure/Function supporting components.
Provides a message channel-specific JDBC API.
Base package for JMS Support.
Base package for JMX support.
Provides Spring Integration components for doing outbound operations.
Provides classes supporting JSON in Spring Integration.
Provides classes related to message channel implementations for Apache Kafka.
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 Spring Integration components for doing outbound operations.
Provides classes for supporting R2DBC outbound components.
Provides classes related to Redis-backed channels.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes supporting the router pattern.
Provides classes representing inbound RSocket components.
Provides classes representing outbound RSocket components.
Provides classes supporting the Scatter-Gather pattern.
Provides classes supporting SFTP gateways.
Provides classes for the SFTP outbound channel adapter.
Outbound Channel Adapter implementations for SMB protocol.
Provides classes supporting the splitter pattern.
Provides classes which represent inbound STOMP components.
Provides classes which represent outbound STOMP components.
Base package for stream support.
Provides classes for inbound endpoints.
Utilities for mocking integration components.
Provides classes supporting the use of transactions and
 pseudo transactions in Spring Integration applications.
Contains core-implementation of various Transformers which includes Enrichers and Filters.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes which represent inbound WebSocket components.
Provides classes which represent outbound WebSocket components.
Provides several inbound and outbound Web Service components.
Provides XML message routers.
Provides implementations of
 
AbstractMessageSplitter.Provides Transformer and Enricher implementations.
Provides classes shared across all XMPP components.
Provides XMPP inbound Endpoint implementations that extend
 
AbstractXmppConnectionAwareEndpoint.Provides XMPP outbound MessageHandler implementations.
Provides classes for message channels support over ZeroMQ.
Provides classes for inbound channel adapters over ZeroMQ.
Provides classes for outbound channel adapters over ZeroMQ.
Classes to support Splitter pattern for Zip.
Classes to support Transformer pattern for Zip.
- 
Uses of ComponentSourceAware in org.springframework.integration.aggregatorClasses in org.springframework.integration.aggregator that implement ComponentSourceAwareModifier 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.classThis Endpoint serves as a barrier for messages that should not be processed yet.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 ComponentSourceAware in org.springframework.integration.amqp.channelClasses in org.springframework.integration.amqp.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe baseAbstractMessageChannelimplementation for AMQP.classTheAbstractSubscribableAmqpChannelimplementation for one-to-one subscription over AMQP queue.classAPollableChannelimplementation that is backed by an AMQP Queue.classTheAbstractSubscribableAmqpChannelextension for pub-sub semantics based on theFanoutExchange.
- 
Uses of ComponentSourceAware in org.springframework.integration.amqp.inboundClasses in org.springframework.integration.amqp.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAdapter that receives Messages from an AMQP Queue, converts them into Spring Integration messages and sends the results to a Message Channel.classAdapter that receives Messages from an AMQP Queue, converts them into Spring Integration messages and sends the results to a Message Channel.
- 
Uses of ComponentSourceAware in org.springframework.integration.amqp.outboundClasses in org.springframework.integration.amqp.outbound that implement ComponentSourceAwareModifier 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.classMessageHandlerbased onRabbitStreamOperations.
- 
Uses of ComponentSourceAware in org.springframework.integration.camel.outboundClasses in org.springframework.integration.camel.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageHandlerfor calling Apache Camel route and produce (optionally) a reply.
- 
Uses of ComponentSourceAware in org.springframework.integration.cassandra.outboundClasses in org.springframework.integration.cassandra.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlerimplementation for Cassandra outbound operations.
- 
Uses of ComponentSourceAware in org.springframework.integration.channelClasses in org.springframework.integration.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheAbstractSubscribableChannelbase implementation for those inheritors which logic may be based on theExecutor.classBase class forMessageChannelimplementations providing common properties such as the channel name.classBase class for all pollable channels.classBase implementation ofMessageChannelthat invokes the subscribedhandler(s)by delegating to aMessageDispatcher.classConverts a channel to a name, retaining a reference to the channel keyed by the name.classA channel that invokes a single subscriber for each sent Message.classAn implementation ofMessageChannelthat delegates to an instance ofUnicastingDispatcherwhich in turn delegates all dispatching invocations to anExecutor.classTheAbstractMessageChannelimplementation for the Reactive StreamsPublisherbased on the Project ReactorFlux.classAnAbstractExecutorChannelimplementation for partitioned message dispatching.classA message channel that prioritizes messages based on aComparator.classA channel that sends Messages to each of its subscribers.classSimple implementation of a message channel.classA zero-capacity version ofQueueChannelthat delegates to aSynchronousQueueinternally.
- 
Uses of ComponentSourceAware in org.springframework.integration.codecClasses in org.springframework.integration.codec that implement ComponentSourceAware
- 
Uses of ComponentSourceAware in org.springframework.integration.contextClasses in org.springframework.integration.context that implement ComponentSourceAwareModifier and TypeClassDescriptionclassA base class that provides convenient access to the bean factory as well asTaskSchedulerandConversionServiceinstances.
- 
Uses of ComponentSourceAware in org.springframework.integration.debezium.inboundClasses in org.springframework.integration.debezium.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassDebezium Change Event Channel Adapter.
- 
Uses of ComponentSourceAware in org.springframework.integration.dslClasses in org.springframework.integration.dsl that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe baseAdapterclass for theIntegrationFlowabstraction.classThe standard implementation of theIntegrationFlowinterface instantiated by the Framework.
- 
Uses of ComponentSourceAware in org.springframework.integration.endpointClasses in org.springframework.integration.endpoint that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe base class for Message Endpoint implementations.classAnAbstractEndpointextension for Polling Consumer pattern basics.classMessage Endpoint that connects anyMessageHandlerimplementation to aSubscribableChannel.classAMessageProducerSupportsubclass 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.classMessage Endpoint that connects anyMessageHandlerimplementation to aPollableChannel.classTheMessageProducerSupportto adapt a providedMessageSourceinto aFluxand let it be subscribed in theMessageProducerSupport.subscribeToPublisher(org.reactivestreams.Publisher<? extends org.springframework.messaging.Message<?>>).classAnAbstractEndpointimplementation for Reactive Streams subscription into an input channel and reactive consumption of messages from that channel.classA Channel Adapter implementation for connecting aMessageSourceto aMessageChannel.
- 
Uses of ComponentSourceAware in org.springframework.integration.event.inboundClasses in org.springframework.integration.event.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAn inbound Channel Adapter that implementsGenericApplicationListenerand passes SpringApplicationEventswithin messages.
- 
Uses of ComponentSourceAware in org.springframework.integration.event.outboundClasses in org.springframework.integration.event.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclass
- 
Uses of ComponentSourceAware in org.springframework.integration.fileClasses in org.springframework.integration.file that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageHandlerimplementation that writes the Message payload to a file.
- 
Uses of ComponentSourceAware in org.springframework.integration.file.remote.gatewayClasses in org.springframework.integration.file.remote.gateway that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for Outbound Gateways that perform remote file operations.
- 
Uses of ComponentSourceAware in org.springframework.integration.file.remote.handlerClasses in org.springframework.integration.file.remote.handler that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageHandlerimplementation that transfers files to a remote server.
- 
Uses of ComponentSourceAware in org.springframework.integration.file.splitterClasses in org.springframework.integration.file.splitter that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheAbstractMessageSplitterimplementation to split theFileMessage payload to lines.
- 
Uses of ComponentSourceAware in org.springframework.integration.file.tailClasses in org.springframework.integration.file.tail that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.filterClasses in org.springframework.integration.filter that implement ComponentSourceAware
- 
Uses of ComponentSourceAware in org.springframework.integration.ftp.gatewayClasses in org.springframework.integration.ftp.gateway that implement ComponentSourceAwareModifier and TypeClassDescriptionclassOutbound Gateway for performing remote file operations via FTP/FTPS.
- 
Uses of ComponentSourceAware in org.springframework.integration.ftp.outboundClasses in org.springframework.integration.ftp.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe FTP specificFileTransferringMessageHandlerextension.
- 
Uses of ComponentSourceAware in org.springframework.integration.gatewayClasses in org.springframework.integration.gateway that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAGatewayProxyFactoryBeanextension for Java configuration.classTheAbstractReplyProducingMessageHandlerimplementation for mid-flow Gateway.classGenerates a proxy for the provided service interface to enable interaction with messaging components without application code being aware of them allowing for POJO-style interaction.classA convenient base class for connecting application code toMessageChannels for sending, receiving, or request-reply operations.
- 
Uses of ComponentSourceAware in org.springframework.integration.graphql.outboundClasses in org.springframework.integration.graphql.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlercapable of fielding GraphQL Query, Mutation and Subscription requests.
- 
Uses of ComponentSourceAware in org.springframework.integration.handlerClasses in org.springframework.integration.handler that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class forMessageHandlerimplementations.classThe baseAbstractMessageHandlerimplementation for theMessageProducer.classBase class forReactiveMessageHandlerimplementations.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.classAMessageHandlerthat evaluates the providedExpressionexpecting a void return.classMessageHandler implementation that simply logs the Message or its payload depending on the value of the 'shouldLogFullMessage' or SpEL 'logExpression' property.classA compositeMessageHandlerimplementation that invokes a chain of MessageHandler instances in order.classBase class for Message handling components that provides basic validation and error handling capabilities.classAMessageHandlerthat invokes the specified method on the provided object.classTheAbstractReplyProducingMessageHandlerwrapper around rawMessageHandlerfor request-reply scenarios, e.g.classThe standard Service Activator pattern implementation.
- 
Uses of ComponentSourceAware in org.springframework.integration.handler.adviceClasses in org.springframework.integration.handler.advice that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe baseHandleMessageAdvicefor advices which can be applied only for theMessageHandler.handleMessage(Message).classBase class forMessageHandleradvice classes.classTheAbstractRequestHandlerAdviceimplementation for cachingAbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)results.classAnAbstractRequestHandlerAdviceimplementation to store and reset a value into/from some context (e.g.classUsed to adviseMessageHandlers.classTheMethodInterceptorimplementation for the Idempotent Receiver E.I.classTheAbstractRequestHandlerAdviceto ensure exclusive access to theAbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)calls based on thelockKeyfrom message.classAnAbstractRequestHandlerAdviceextension for a rate limiting to service method calls.classA circuit breaker that stops calling a failing service after threshold failures, until halfOpenAfter milliseconds has elapsed.classTheAbstractRequestHandlerAdviceimplementation for retrying the targetMessageHandlerexecution.
- 
Uses of ComponentSourceAware in org.springframework.integration.hazelcast.inboundClasses in org.springframework.integration.hazelcast.inbound that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.hazelcast.outboundClasses in org.springframework.integration.hazelcast.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassMessageHandler implementation that writesMessageor payload to defined Hazelcast distributed cache object.
- 
Uses of ComponentSourceAware in org.springframework.integration.http.inboundClasses in org.springframework.integration.http.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheMessagingGatewaySupportextension for HTTP Inbound endpoints with basic properties.classInbound HTTP endpoint that implements Spring'sControllerinterface to be used with a DispatcherServlet front controller.classBase class for HTTP request handling endpoints.classInbound Messaging Gateway that handles HTTP Requests.
- 
Uses of ComponentSourceAware in org.springframework.integration.http.outboundClasses in org.springframework.integration.http.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for http outbound adapter/gateway.classAMessageHandlerimplementation that executes HTTP requests by delegating to aRestTemplateinstance.
- 
Uses of ComponentSourceAware in org.springframework.integration.ipClasses in org.springframework.integration.ip that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for inbound TCP/UDP Channel Adapters.classBase class for UDP MessageHandlers.
- 
Uses of ComponentSourceAware in org.springframework.integration.ip.tcpClasses in org.springframework.integration.ip.tcp that implement ComponentSourceAwareModifier and TypeClassDescriptionclassInbound Gateway using a server connection factory - threading is controlled by the factory.classTCP 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.classTcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections.
- 
Uses of ComponentSourceAware in org.springframework.integration.ip.tcp.connectionClasses in org.springframework.integration.ip.tcp.connection that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAbstract class for client connection factories; client connection factories establish outgoing connections.classBase class for all connection factories.classBase class for all server connection factories.classConnection factory that caches connections from the underlying target factory.classGiven a list of connection factories, serves upTcpConnections that can iterate over a connection from each factory until thewritesucceeds or the list is exhausted.classA client connection factory that createsTcpNetConnections.classImplements a server connection factory that producesTcpNetConnections using aServerSocket.classA client connection factory that createsTcpNioConnections.class/** Implements a server connection factory that producesTcpNioConnections using aServerSocketChannel.classA client connection factory that binds a connection to a thread.
- 
Uses of ComponentSourceAware in org.springframework.integration.ip.udpClasses in org.springframework.integration.ip.udp that implement ComponentSourceAwareModifier and TypeClassDescriptionclassChannel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.classAMessageHandlerimplementation 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.classA channel adapter to receive incoming UDP packets.classAMessageHandlerimplementation that maps a Message into a UDP datagram packet and sends that to the specified host and port.
- 
Uses of ComponentSourceAware in org.springframework.integration.jdbcClasses in org.springframework.integration.jdbc that implement ComponentSourceAwareModifier and TypeClassDescriptionclassA message handler that executes an SQL update.classclassA message handler that executes Stored Procedures for update purposes.classAnAbstractReplyProducingMessageHandlerimplementation for performing RDBMS stored procedures which return results.
- 
Uses of ComponentSourceAware in org.springframework.integration.jdbc.channelClasses in org.springframework.integration.jdbc.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAnAbstractSubscribableChannelfor receiving push notifications for messages send to a group id of aJdbcChannelMessageStore.
- 
Uses of ComponentSourceAware in org.springframework.integration.jmsClasses in org.springframework.integration.jms that implement ComponentSourceAwareModifier and TypeClassDescriptionclassA baseAbstractMessageChannelimplementation for JMS-backed message channels.classA wrapper around theJmsMessageDrivenEndpointimplementingMessagingGatewaySupport.classA 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.classA MessageConsumer that sends the converted Message payload within a JMS Message.classA JMS-backed channel from which messages can be received through polling.classAnAbstractJmsChannelimplementation for message-driven subscriptions.
- 
Uses of ComponentSourceAware in org.springframework.integration.jmxClasses in org.springframework.integration.jmx that implement ComponentSourceAwareModifier and TypeClassDescriptionclassA JMXNotificationListenerimplementation that will send Messages containing the JMXNotificationinstances as their payloads.classAnAbstractMessageHandlerimplementation to publish an incoming message as a JMXNotification.classAMessageHandlerimplementation for invoking JMX operations based on the Message sent to itsAbstractMessageHandler.handleMessage(Message)method.
- 
Uses of ComponentSourceAware in org.springframework.integration.jpa.outboundClasses in org.springframework.integration.jpa.outbound that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.jsonClasses in org.springframework.integration.json that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTransformer implementation that converts a JSON string payload into an instance of the provided target Class.classTransformer implementation that converts a payload instance into a JSON string representation.
- 
Uses of ComponentSourceAware in org.springframework.integration.kafka.channelClasses in org.springframework.integration.kafka.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAbstract MessageChannel backed by an Apache Kafka topic.classPollable channel backed by an Apache Kafka topic.classPublish/subscribe channel backed by an Apache Kafka topic.classSubscribable channel backed by an Apache Kafka topic.
- 
Uses of ComponentSourceAware in org.springframework.integration.kafka.inboundClasses in org.springframework.integration.kafka.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassKafkaInboundGateway<K,V, R> Inbound gateway.classMessage-driven channel adapter.
- 
Uses of ComponentSourceAware in org.springframework.integration.kafka.outboundClasses in org.springframework.integration.kafka.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassA Message Handler for Apache Kafka; when supplied with aReplyingKafkaTemplateit is used as the handler in an outbound gateway.
- 
Uses of ComponentSourceAware in org.springframework.integration.mailClasses in org.springframework.integration.mail that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class forMailReceiverimplementations.classAn event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177).classAMailReceiverimplementation for receiving mail messages from a mail server that supports the IMAP protocol.classAMessageHandlerimplementation for sending mail.classAMailReceiverimplementation that polls a mail server using the POP3 protocol.
- 
Uses of ComponentSourceAware in org.springframework.integration.mongodb.inboundClasses in org.springframework.integration.mongodb.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageProducerSupportfor MongoDB Change Stream implementation.
- 
Uses of ComponentSourceAware in org.springframework.integration.mongodb.outboundClasses in org.springframework.integration.mongodb.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassMakes outbound operations to query a MongoDb database using aMongoOperations.classImplementation ofMessageHandlerwhich writes Message payload into a MongoDb collection identified by evaluation of theMongoDbStoringMessageHandler.collectionNameExpression.classImplementation ofReactiveMessageHandlerwhich writes Message payload into a MongoDb collection, using reactive MongoDb support, The collection is identified by evaluation of theReactiveMongoDbStoringMessageHandler.collectionNameExpression.
- 
Uses of ComponentSourceAware in org.springframework.integration.mqtt.inboundClasses in org.springframework.integration.mqtt.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAbstract class for MQTT Message-Driven Channel Adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageDrivenChannelAdapterimplementation for MQTT v5.
- 
Uses of ComponentSourceAware in org.springframework.integration.mqtt.outboundClasses in org.springframework.integration.mqtt.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAbstract class for MQTT outbound channel adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageHandlerimplementation for MQTT v5.
- 
Uses of ComponentSourceAware in org.springframework.integration.r2dbc.outboundClasses in org.springframework.integration.r2dbc.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassImplementation ofReactiveMessageHandlerwhich writes Message payload into a Relational Database, using reactive r2dbc support.
- 
Uses of ComponentSourceAware in org.springframework.integration.redis.channelClasses in org.springframework.integration.redis.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAnAbstractMessageChannelimplementation withBroadcastCapableChannelaspect to provide a pub-sub semantics to consume messages fgrom Redis topic.
- 
Uses of ComponentSourceAware in org.springframework.integration.redis.inboundClasses in org.springframework.integration.redis.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageProducerSupportfor reading messages from a Redis Stream and publishing them into the provided output channel.classclassclass
- 
Uses of ComponentSourceAware in org.springframework.integration.redis.outboundClasses in org.springframework.integration.redis.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassImplementation ofReactiveMessageHandlerwhich writes Message payload or Message itself (seeReactiveRedisStreamMessageHandler.extractPayload) into a Redis stream using Reactive Stream operations.classThe Gateway component implementation to perform Redis commands with provided arguments and to return command result.classclassclassclassImplementation ofMessageHandlerwhich writes Message data into a Redis store identified by a keyString.
- 
Uses of ComponentSourceAware in org.springframework.integration.routerClasses in org.springframework.integration.router that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for all Message Routers that support mapping from arbitrary String values to Message Channel names.classBase class for all Message Routers.classA Message Router that resolves the targetMessageChannelfor messages whose payload is aThrowable.classA Message Router implementation that evaluates the specified SpEL expression.classA Message Router that resolves the MessageChannel from a header value.classA Message Router that invokes the specified method on the given object.classA Message Router that resolves theMessageChannelbased on theMessage'spayload type.class<recipient-list-router id="simpleRouter" input-channel="routingChannelA"> <recipient channel="channel1"/> <recipient channel="channel2"/> </recipient-list-router>
- 
Uses of ComponentSourceAware in org.springframework.integration.rsocket.inboundClasses in org.springframework.integration.rsocket.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheMessagingGatewaySupportimplementation for theIntegrationRSocketEndpoint.
- 
Uses of ComponentSourceAware in org.springframework.integration.rsocket.outboundClasses in org.springframework.integration.rsocket.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAn Outbound Messaging Gateway for RSocket requests.
- 
Uses of ComponentSourceAware in org.springframework.integration.scattergatherClasses in org.springframework.integration.scattergather that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheMessageHandlerimplementation for the Scatter-Gather EIP pattern.
- 
Uses of ComponentSourceAware in org.springframework.integration.sftp.gatewayClasses in org.springframework.integration.sftp.gateway that implement ComponentSourceAwareModifier and TypeClassDescriptionclassOutbound Gateway for performing remote file operations via SFTP.
- 
Uses of ComponentSourceAware in org.springframework.integration.sftp.outboundClasses in org.springframework.integration.sftp.outbound that implement ComponentSourceAware
- 
Uses of ComponentSourceAware in org.springframework.integration.smb.outboundClasses in org.springframework.integration.smb.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThe SMB specificFileTransferringMessageHandlerextension.classOutbound Gateway for performing remote file operations via SMB.
- 
Uses of ComponentSourceAware in org.springframework.integration.splitterClasses in org.springframework.integration.splitter that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.stomp.inboundClasses in org.springframework.integration.stomp.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheMessageProducerSupportfor STOMP protocol to handle STOMP frames from provided destination and send messages to theoutputChannel.
- 
Uses of ComponentSourceAware in org.springframework.integration.stomp.outboundClasses in org.springframework.integration.stomp.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheAbstractMessageHandlerimplementation to send messages to STOMP destinations.
- 
Uses of ComponentSourceAware in org.springframework.integration.streamClasses in org.springframework.integration.stream that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageHandlerthat writes a byte array to anOutputStream.classAMessageHandlerthat writes characters to aWriter.
- 
Uses of ComponentSourceAware in org.springframework.integration.syslog.inboundClasses in org.springframework.integration.syslog.inbound that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.test.mockClasses in org.springframework.integration.test.mock that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheAbstractMessageProducingHandlerextension for the mocking purpose in tests.
- 
Uses of ComponentSourceAware in org.springframework.integration.transactionClasses in org.springframework.integration.transaction that implement ComponentSourceAwareModifier and TypeClassDescriptionclassThis implementation ofTransactionSynchronizationFactoryallows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - seeTransactionSynchronization.
- 
Uses of ComponentSourceAware in org.springframework.integration.transformerClasses in org.springframework.integration.transformer that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for Message Transformers that delegate to aMessageProcessor.classA base class forTransformerimplementations that modify the payload of aMessage.classA base class forTransformerimplementations.classTransformer that stores a Message and returns a new Message whose payload is the id of the stored Message.classTransformer that accepts a Message whose payload is a UUID and retrieves the Message associated with that id from a MessageStore if available.classContent 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.classAbstractPayloadTransformerthat delegates to a codec to decode the payload from a byte[].classAbstractPayloadTransformerthat delegates to a codec to encode the payload into a byte[].classA Message Transformer implementation that evaluates the specified SpEL expression.classA Protocol Buffer transformer to instantiateMessageobjects from eitherbyte[]if content type isapplication/x-protobufor fromStringin case ofapplication/jsoncontent type.classA Transformer that adds statically configured header values to a Message.classTransformer that removes Message headers.classWill transform Map to an instance of Object.classA reply-producingMessageHandlerthat delegates to aTransformerinstance to modify the receivedMessageand sends the result to its output channel.classA Message Transformer implementation that invokes the specified method on the given object.classTransforms an object graph into a Map.classA simple transformer that creates an outbound payload by invoking the inbound payload Object'stoString()method.classTransformer that deserializes the inbound byte array payload to an object by delegating to a Converter<byte[], Object>.classTransformer that serializes the inbound payload into a byte array by delegating to theSerializingConverterusing Java serialization.classTransformer that converts the inbound payload to an object by delegating to a Converter<Object, Object>.classAn Apache Avro transformer to create generatedSpecificRecordobjects frombyte[].classAn Apache Avro transformer for generatedSpecificRecordobjects.classclassTransforms a packet in Syslog (RFC3164) format to a Map.classA Protocol Buffer transformer for generatedMessageobjects.
- 
Uses of ComponentSourceAware in org.springframework.integration.webflux.inboundClasses in org.springframework.integration.webflux.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessagingGatewaySupportimplementation for Spring WebFlux HTTP requests execution.
- 
Uses of ComponentSourceAware in org.springframework.integration.webflux.outboundClasses in org.springframework.integration.webflux.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageHandlerimplementation that executes HTTP requests by delegating to a ReactiveWebClientinstance.
- 
Uses of ComponentSourceAware in org.springframework.integration.websocket.inboundClasses in org.springframework.integration.websocket.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheMessageProducerSupportfor inbound WebSocket messages.
- 
Uses of ComponentSourceAware in org.springframework.integration.websocket.outboundClasses in org.springframework.integration.websocket.outbound that implement ComponentSourceAware
- 
Uses of ComponentSourceAware in org.springframework.integration.wsClasses in org.springframework.integration.ws that implement ComponentSourceAwareModifier and TypeClassDescriptionclassclassBase class for outbound Web Service-invoking Messaging Gateways.classclassAn outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.classclassAn outbound Messaging Gateway for invoking a Web Service.
- 
Uses of ComponentSourceAware in org.springframework.integration.xml.routerClasses in org.springframework.integration.xml.router that implement ComponentSourceAwareModifier and TypeClassDescriptionclassMessage Router that usesXPathExpressionevaluation to determine channel names.
- 
Uses of ComponentSourceAware in org.springframework.integration.xml.splitterClasses in org.springframework.integration.xml.splitter that implement ComponentSourceAwareModifier and TypeClassDescriptionclassMessage Splitter that uses anXPathExpressionto split aDocument,FileorStringpayload into aNodeList.
- 
Uses of ComponentSourceAware in org.springframework.integration.xml.transformerClasses in org.springframework.integration.xml.transformer that implement ComponentSourceAwareModifier and TypeClassDescriptionclassSuper class for XML transformers.classAn implementation ofAbstractTransformerthat delegates to an OXMMarshaller.classTransforms the payload to aSourceusing aSourceFactory.classAn implementation ofTransformerthat delegates to an OXMUnmarshaller.classTransformer implementation that evaluates XPath expressions against the message payload and inserts the result of the evaluation into a message header.classTransformer implementation that evaluates an XPath expression against the inbound Message payload and returns a Message whose payload is the result of that evaluation.class
- 
Uses of ComponentSourceAware in org.springframework.integration.xmpp.coreClasses in org.springframework.integration.xmpp.core that implement ComponentSourceAwareModifier and TypeClassDescriptionclassclass
- 
Uses of ComponentSourceAware in org.springframework.integration.xmpp.inboundClasses in org.springframework.integration.xmpp.inbound that implement ComponentSourceAwareModifier 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 ComponentSourceAware in org.springframework.integration.xmpp.outboundClasses in org.springframework.integration.xmpp.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassMessageHandler that sends an XMPP Chat Message.classMessageHandler that publishes updated Presence values for a given XMPP connection.
- 
Uses of ComponentSourceAware in org.springframework.integration.zeromq.channelClasses in org.springframework.integration.zeromq.channel that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheSubscribableChannelimplementation over ZeroMQ sockets.
- 
Uses of ComponentSourceAware in org.springframework.integration.zeromq.inboundClasses in org.springframework.integration.zeromq.inbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassAMessageProducerSupportimplementation for consuming messages from ZeroMq socket.
- 
Uses of ComponentSourceAware in org.springframework.integration.zeromq.outboundClasses in org.springframework.integration.zeromq.outbound that implement ComponentSourceAwareModifier and TypeClassDescriptionclassTheAbstractReactiveMessageHandlerimplementation for publishing messages over ZeroMq socket.
- 
Uses of ComponentSourceAware in org.springframework.integration.zip.splitterClasses in org.springframework.integration.zip.splitter that implement ComponentSourceAware
- 
Uses of ComponentSourceAware in org.springframework.integration.zip.transformerClasses in org.springframework.integration.zip.transformer that implement ComponentSourceAwareModifier and TypeClassDescriptionclassBase class for transformers that provide Zip compression.classTransformer implementation that applies an UnZip transformation to the message payload.classTransformerimplementation that applies a Zip transformation to the message payload.